2025.06.25 16:06:57.916379 [ 418 ] {} Context: Server was built in debug mode. It will work slowly. 2025.06.25 16:06:57.917443 [ 418 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.25 16:06:58.539723 [ 418 ] {} 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.06.25 16:06:58.546781 [ 418 ] {} 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.06.25 16:07:02.657844 [ 418 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.06.25 16:07:02.661959 [ 418 ] {} KeeperLogStore: Removing all changelogs 2025.06.25 16:07:02.669955 [ 418 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.25 16:07:02.691437 [ 418 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.25 16:07:02.692046 [ 418 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.25 16:07:02.758553 [ 1066 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.25 16:07:03.314450 [ 418 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.06.25 16:07:03.315064 [ 418 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.06.25 16:07:04.715750 [ 418 ] {} 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.06.25 16:07:18.506801 [ 423 ] {95d260df-93e6-42ab-aeb0-46d58d0ad400} 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.06.25 16:07:31.214942 [ 423 ] {9ae309bf-77b1-4659-8e3d-8b6f79e2b586} 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.06.25 16:07:51.191674 [ 1056 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.06.25 16:07:57.215475 [ 1381 ] {} Context: Server was built in debug mode. It will work slowly. 2025.06.25 16:07:57.216581 [ 1381 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.25 16:07:57.694780 [ 1381 ] {} 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.06.25 16:07:57.700033 [ 1381 ] {} 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.06.25 16:08:01.724529 [ 1381 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.25 16:08:01.753731 [ 1381 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.25 16:08:01.754488 [ 1381 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.25 16:08:01.828577 [ 2017 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.25 16:08:11.083909 [ 1381 ] {} 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.06.25 16:09:08.292807 [ 2045 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.06.25 16:09:08.295748 [ 2045 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.06.25 16:09:10.843834 [ 1386 ] {2eef5b6a-18b4-4e59-ba2b-5da08ffa9f44} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1179552 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column RefererDomain): (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 516 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58424) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 8. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 9. /build/src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d64885 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 20. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007ff7fdedcac3 30. ? @ 0x00007ff7fdf6e850 2025.06.25 16:09:12.266251 [ 2057 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0576d149-6ca8-4a86-ae51-efdadd389a86::202506_1_5_1}: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 16.89 GiB (attempt to allocate chunk of 1050256 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit isn't used. Waiting time or overcommit denominator are set to zero. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 8. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 9. /build/src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000c62369b 10. /build/src/Common/PODArray.h:154: void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x000000000702e8f6 11. /build/src/Common/PODArray.h:0: DB::ColumnVector::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000120683fd 12. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::CheckSortedTransform::transform(DB::Chunk&) @ 0x0000000012f94215 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 14. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 16. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 17. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 18. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 20. /build/src/Storages/MergeTree/MergeTask.cpp:555: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() @ 0x0000000012757332 21. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 22. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 23. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 26. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 27. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 28. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 30. ? @ 0x00007ff7fdedcac3 31. ? @ 0x00007ff7fdf6e850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:09:38.775418 [ 1386 ] {2eef5b6a-18b4-4e59-ba2b-5da08ffa9f44} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1179552 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column RefererDomain): (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 516 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 8. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 9. /build/src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d64885 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 20. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007ff7fdedcac3 30. ? @ 0x00007ff7fdf6e850 2025.06.25 16:09:55.242650 [ 2045 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.06.25 16:09:59.522806 [ 2058 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_1_31_6}: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.56 GiB (attempt to allocate chunk of 1475996 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit isn't used. Waiting time or overcommit denominator are set to zero. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 8. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 9. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 10. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 11. /build/src/IO/BufferWithOwnMemory.h:50: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000c6cccfb 12. /build/src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000c6cc2ce 13. /build/contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000c7b7350 14. /build/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&) @ 0x0000000010f00027 15. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9672 16. /build/src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000126b8f71 17. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:141: DB::IMergeTreeDataPart::MinMaxIndex::store(std::vector> const&, std::vector, std::allocator>> const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x00000000126df2a4 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IMergeTreeDataPart::MinMaxIndex::store(DB::MergeTreeData const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x00000000126def5d 19. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000012954fcd 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000012953c6c 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergedBlockOutputStream::finalizePart(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000012953444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::MergeProjectionsStage::finalizeProjectionsAndWholeMerge() const @ 0x000000001275bc56 23. /build/src/Storages/MergeTree/MergeTask.cpp:1020: DB::MergeTask::MergeProjectionsStage::execute() @ 0x000000001275bf15 24. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 25. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:10:00.389134 [ 1386 ] {c1d0531e-1505-47e6-ac8e-68d747740475} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.62 GiB (attempt to allocate chunk of 1048991 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ClientIP6): (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 564 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42142) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 8. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 9. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 10. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 11. /build/src/IO/BufferWithOwnMemory.h:76: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x00000000106a1cef 12. /build/contrib/llvm-project/libcxx/include/optional:344: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8b7e 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128f6f6f 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000128f6a6f 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:142: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f71ab 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 21. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:10:15.503460 [ 1386 ] {c1d0531e-1505-47e6-ac8e-68d747740475} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.62 GiB (attempt to allocate chunk of 1048991 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ClientIP6): (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 564 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 7. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 8. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 9. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 10. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 11. /build/src/IO/BufferWithOwnMemory.h:76: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x00000000106a1cef 12. /build/contrib/llvm-project/libcxx/include/optional:344: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8b7e 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128f6f6f 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000128f6a6f 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:142: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f71ab 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 21. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:10:44.360879 [ 2045 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.06.25 16:11:02.581072 [ 2022 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.06.25 16:11:04.147070 [ 2947 ] {} Context: Server was built in debug mode. It will work slowly. 2025.06.25 16:11:04.148218 [ 2947 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.06.25 16:11:04.699870 [ 2947 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.25 16:11:04.707381 [ 2947 ] {} 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.06.25 16:11:04.716297 [ 2947 ] {} 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.06.25 16:11:09.085860 [ 2947 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.25 16:11:09.164568 [ 2947 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.25 16:11:09.165243 [ 2947 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.25 16:11:09.237938 [ 3598 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.25 16:11:17.261644 [ 2947 ] {} 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.06.25 16:11:19.275664 [ 2952 ] {d42dc6c7-411a-4711-9850-0c7eb17642c8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46124) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:19.278721 [ 2952 ] {d42dc6c7-411a-4711-9850-0c7eb17642c8} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:24.493085 [ 2952 ] {6dc22fce-17b4-457c-a658-d2822d6c55b8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=717, jobs=705). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57072) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:24.505585 [ 2952 ] {6dc22fce-17b4-457c-a658-d2822d6c55b8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=717, jobs=705). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:40.476444 [ 2956 ] {d1d0b76f-8a26-4ad1-af0d-cff427885564} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44838) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:11:40.482393 [ 2956 ] {d1d0b76f-8a26-4ad1-af0d-cff427885564} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:41.220312 [ 3628 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0576d149-6ca8-4a86-ae51-efdadd389a86::202506_1_17_3}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:43.040710 [ 2956 ] {68dc8371-679b-4c16-bf55-1b568a2ba48d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45102) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:11:43.046918 [ 2956 ] {68dc8371-679b-4c16-bf55-1b568a2ba48d} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:43.272709 [ 4027 ] {e207f1fe-34d8-40a1-b9c4-daa73b8416e5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45152) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:11:43.278173 [ 4027 ] {e207f1fe-34d8-40a1-b9c4-daa73b8416e5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:43.842732 [ 2956 ] {7be70073-4b47-49a9-aaa1-4c742be21d6b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45234) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:11:43.849801 [ 2956 ] {7be70073-4b47-49a9-aaa1-4c742be21d6b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:44.305068 [ 4014 ] {e4d80cf2-e2ce-4168-ad2b-80d5a6a617d6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58734) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:11:44.338627 [ 4014 ] {e4d80cf2-e2ce-4168-ad2b-80d5a6a617d6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:11:44.956800 [ 4027 ] {9e9eb08a-1b87-4ca6-88d0-eb40f36fe266} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39778) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:44.982205 [ 4027 ] {9e9eb08a-1b87-4ca6-88d0-eb40f36fe266} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:45.370050 [ 4027 ] {fdf23648-fcbf-4fd8-bf9d-ba5aafe9c129} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48878) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:11:45.376278 [ 4027 ] {fdf23648-fcbf-4fd8-bf9d-ba5aafe9c129} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:46.019679 [ 2956 ] {11add1b4-e754-44a6-bc7b-4e312a4a8c19} 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.10505.altinitytest (altinity build)) (from [::1]:39788) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:46.089714 [ 2956 ] {11add1b4-e754-44a6-bc7b-4e312a4a8c19} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:46.277166 [ 4027 ] {760e794a-aaed-4bc9-b84b-a63bb1d04a28} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39800) (comment: 01308_polygon_area.sql) (in query: SELECT polygonAreaCartesian([]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/geometryConverters.h:0: DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aff74f3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:11:46.280229 [ 4027 ] {760e794a-aaed-4bc9-b84b-a63bb1d04a28} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/geometryConverters.h:0: DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aff74f3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:11:46.653423 [ 4006 ] {1e9d0d33-810a-4ffd-b1c7-1ec8d914a670} executeQuery: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39784) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge() ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:11:46.656579 [ 4006 ] {1e9d0d33-810a-4ffd-b1c7-1ec8d914a670} TCPHandler: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:11:46.892654 [ 4006 ] {22f3a452-376a-40d9-b1f9-89fbf263936d} executeQuery: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_r3524yrw`, or there are no tables in database matches `test_r3524yrw`, which fit tables expression: ^t. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39784) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge('^t') ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:11:46.895403 [ 4006 ] {22f3a452-376a-40d9-b1f9-89fbf263936d} TCPHandler: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_r3524yrw`, or there are no tables in database matches `test_r3524yrw`, which fit tables expression: ^t. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:11:47.273031 [ 4006 ] {c2818204-53bf-4409-8fb8-75d8a712a74a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39784) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:47.281114 [ 4006 ] {c2818204-53bf-4409-8fb8-75d8a712a74a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:47.434233 [ 4108 ] {76e07e89-5e34-447e-8bb1-cd27cb5dc5f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49106) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:11:47.437587 [ 4108 ] {76e07e89-5e34-447e-8bb1-cd27cb5dc5f9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:47.753837 [ 3998 ] {8322ce02-c785-4894-9a60-1e98a160a326} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39820) (comment: 02304_grouping_sets_with_rollup_cube.sql) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011034aab 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 10. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:11:47.756446 [ 3998 ] {8322ce02-c785-4894-9a60-1e98a160a326} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011034aab 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 10. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:11:47.796918 [ 2956 ] {b803bfe0-664b-4153-a758-75306a729f84} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49194) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:11:47.812662 [ 2956 ] {b803bfe0-664b-4153-a758-75306a729f84} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:47.849319 [ 3998 ] {c2f8fd0b-b0ab-4847-8ea1-2e845b7cde8f} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39820) (comment: 02304_grouping_sets_with_rollup_cube.sql) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011034aab 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 10. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:11:47.854209 [ 3998 ] {c2f8fd0b-b0ab-4847-8ea1-2e845b7cde8f} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011034aab 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 7. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 10. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 11. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:11:48.107755 [ 4027 ] {82c33ae3-cc87-46b4-89cd-1f64c094b7de} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39832) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE IF EXISTS 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:48.118545 [ 4027 ] {82c33ae3-cc87-46b4-89cd-1f64c094b7de} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:49.392720 [ 4108 ] {c7e7d1a2-da29-4e61-8555-667d41230165} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39854) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Tuple(pull_request Tuple(merged_by Tuple(login String)))', '{"payload" : {"pull_request": {"merged_by": null}}}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72d7f 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:328: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000010d7543d 7. /build/src/DataTypes/Serializations/SerializationTuple.cpp:430: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000010d74c15 8. /build/src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72b26 9. /build/src/DataTypes/Serializations/SerializationTuple.cpp:328: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000010d7543d 10. /build/src/DataTypes/Serializations/SerializationTuple.cpp:430: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000010d74c15 11. /build/src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72b26 12. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 14. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 15. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 16. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 17. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 18. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 19. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 21. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 22. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 23. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 24. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 25. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 26. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 27. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 2025.06.25 16:11:49.407762 [ 4108 ] {c7e7d1a2-da29-4e61-8555-667d41230165} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72d7f 6. /build/src/DataTypes/Serializations/SerializationTuple.cpp:328: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000010d7543d 7. /build/src/DataTypes/Serializations/SerializationTuple.cpp:430: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000010d74c15 8. /build/src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72b26 9. /build/src/DataTypes/Serializations/SerializationTuple.cpp:328: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000010d7543d 10. /build/src/DataTypes/Serializations/SerializationTuple.cpp:430: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000010d74c15 11. /build/src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d72b26 12. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 14. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 15. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 16. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 17. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 18. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 19. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 21. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 22. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 23. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 24. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 25. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 26. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 27. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 2025.06.25 16:11:49.887020 [ 4197 ] {08c86a87-3118-4c37-b1c3-5bc3344ef4aa} executeQuery: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39864) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge() ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:11:49.889319 [ 4197 ] {08c86a87-3118-4c37-b1c3-5bc3344ef4aa} TCPHandler: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:11:49.959916 [ 4197 ] {11cf27b9-f238-48c9-9e8f-2a8d7516f43d} executeQuery: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_0zc2fi1o`, or there are no tables in database matches `test_0zc2fi1o`, which fit tables expression: ^t. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39864) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge('^t') ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:11:49.961863 [ 4197 ] {11cf27b9-f238-48c9-9e8f-2a8d7516f43d} TCPHandler: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_0zc2fi1o`, or there are no tables in database matches `test_0zc2fi1o`, which fit tables expression: ^t. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:11:50.302115 [ 4197 ] {1b065b17-c2ad-4551-84df-580a3d43577a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39864) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:50.313597 [ 4197 ] {1b065b17-c2ad-4551-84df-580a3d43577a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:50.613222 [ 4108 ] {5d3413cd-5bdc-4366-b641-655f94ee8c3a} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39854) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Map(String, Map(String, Map(String, String)))', '{"payload" : {"pull_request": {"merged_by": null}}}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.h:201: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21ec0 6. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21c6b 7. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21c6b 8. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:11:50.629289 [ 4108 ] {5d3413cd-5bdc-4366-b641-655f94ee8c3a} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.h:201: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21ec0 6. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21c6b 7. /build/src/DataTypes/Serializations/SerializationMap.cpp:0: DB::SerializationMap::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d21c6b 8. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:11:51.202800 [ 3639 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_1_28_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:51.450108 [ 4197 ] {f1d653c6-ab31-4b89-9ca5-d8e885b9ae3b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39986) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE IF EXISTS 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:51.452295 [ 4197 ] {f1d653c6-ab31-4b89-9ca5-d8e885b9ae3b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:51.585997 [ 4108 ] {2d028c08-eb2e-413e-91cf-6e99204184e4} executeQuery: Code: 130. DB::Exception: Array does not start with '[' character: (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_READ_ARRAY_FROM_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39854) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Array(String)', '{"payload" : null}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/DataTypes/Serializations/SerializationArray.cpp:442: DB::SerializationArray::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce14ec 5. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 6. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 7. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 8. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 9. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 18. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 20. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 29. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 2025.06.25 16:11:51.588164 [ 4108 ] {2d028c08-eb2e-413e-91cf-6e99204184e4} TCPHandler: Code: 130. DB::Exception: Array does not start with '[' character: (while reading the value of key payload): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_READ_ARRAY_FROM_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/DataTypes/Serializations/SerializationArray.cpp:442: DB::SerializationArray::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce14ec 5. /build/src/Formats/JSONUtils.cpp:292: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e5935f 6. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 7. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 8. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 9. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 18. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 20. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 29. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 2025.06.25 16:11:52.293049 [ 4197 ] {a59bb26e-cf1d-40db-80fd-808bfad2fc2e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49410) (comment: 02459_materialized_view_default_value.sql) (in query: DROP DATABASE IF EXISTS test_ux6tffip ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:52.295895 [ 4197 ] {a59bb26e-cf1d-40db-80fd-808bfad2fc2e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:52.345461 [ 3998 ] {114321ba-31b1-4a04-af17-f83afbd7a9f1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49422) (comment: 02459_materialized_view_default_value.sql) (in query: DROP DATABASE IF EXISTS test_ux6tffip ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:52.346640 [ 3998 ] {114321ba-31b1-4a04-af17-f83afbd7a9f1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:52.848563 [ 2956 ] {0febb69f-284b-4d2c-8990-3493adf8e930} executeQuery: Code: 57. DB::Exception: Table test_m94j5thg.source already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40010) (comment: 02783_date_predicate_optimizations.sql) (in query: CREATE TABLE source (`dt` Date, `ts` DateTime, `dt_32` Date32, `ts_64` DateTime64(3), `n` Int32) ENGINE = MergeTree PARTITION BY toYYYYMM(ts) ORDER BY tuple() SETTINGS index_granularity = 3515, min_bytes_for_wide_part = 450741537, 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 = 237929767, compact_parts_max_granules_to_buffer = 136, compact_parts_merge_max_bytes_to_prefetch_part = 31565240, merge_max_block_size = 22752, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 7889929113, 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 = 21164864, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 42606, primary_key_compress_block_size = 77070), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:11:52.850989 [ 2956 ] {0febb69f-284b-4d2c-8990-3493adf8e930} TCPHandler: Code: 57. DB::Exception: Table test_m94j5thg.source already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:11:53.603319 [ 4197 ] {d0875124-21f6-4241-9a7d-b6777afb4e8e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40072) (comment: 02553_type_json_attach_partition.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:53.605814 [ 4197 ] {d0875124-21f6-4241-9a7d-b6777afb4e8e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:11:54.389494 [ 3998 ] {eb6d9445-39f9-4b18-969b-7f6adfc7f37e} executeQuery: Code: 60. DB::Exception: Table default.non_existing_table does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35060) (in query: INSERT INTO non_existing_table SELECT col1, initializeAggregation('argMaxState', col2, insertTime) as col2, now() as insertTime FROM input('col1 String, col2 Array(Float64)') FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:54.396628 [ 3998 ] {eb6d9445-39f9-4b18-969b-7f6adfc7f37e} DynamicQueryHandler: Code: 60. DB::Exception: Table default.non_existing_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:54.431870 [ 4388 ] {fe752fd6-e583-410f-bf2f-59d86ea06dd0} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39934) (comment: 01251_dict_is_in_infinite_loop.sql) (in query: DROP DICTIONARY IF EXISTS database_for_dict.dictionary_with_hierarchy;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:54.434320 [ 4388 ] {fe752fd6-e583-410f-bf2f-59d86ea06dd0} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:54.674616 [ 4108 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:41474, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/IO/VarInt.h:95: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000000c6c9022 7. /build/src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x0000000012cbd4bd 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb47db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:54.757080 [ 4191 ] {fc98efff-0bda-415e-bcd7-ec0a4445d469} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40520) (comment: 00077_log_tinylog_stripelog.sql) (in query: CHECK TABLE test.hits_tinylog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:54.767602 [ 4191 ] {fc98efff-0bda-415e-bcd7-ec0a4445d469} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:11:55.085240 [ 2956 ] {ede757f2-0ec1-42b0-9485-c4b3a314e985} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40104) (comment: 03146_parameterized_view_with_date.sql) (in query: select * from pv (timestamp_param=toDateTime('2024-040'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x000000000c6c1c4b 4. /build/src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000c6c1b05 5. /build/src/Functions/FunctionsConversion.cpp:632: 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&&) @ 0x00000000072588d8 6. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000724a222 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103c21e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:11:55.136098 [ 2956 ] {ede757f2-0ec1-42b0-9485-c4b3a314e985} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x000000000c6c1c4b 4. /build/src/IO/ReadHelpers.cpp:0: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000c6c1b05 5. /build/src/Functions/FunctionsConversion.cpp:632: 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&&) @ 0x00000000072588d8 6. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000724a222 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103c21e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:11:55.368715 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_1_28_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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:55.481836 [ 4108 ] {a25c4252-172c-4372-9950-be43c662ebd3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33806) (comment: 02990_parts_splitter_invalid_ranges.sql) (in query: DROP DATABASE IF EXISTS test_qt3b76jd ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:55.492680 [ 4108 ] {a25c4252-172c-4372-9950-be43c662ebd3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:55.525588 [ 2956 ] {c15240f4-c41a-4143-a9a4-680ff484a846} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33816) (comment: 02990_parts_splitter_invalid_ranges.sql) (in query: DROP DATABASE IF EXISTS test_qt3b76jd ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:11:55.526822 [ 2956 ] {c15240f4-c41a-4143-a9a4-680ff484a846} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:56.954174 [ 3840 ] {} virtual void DB::SystemLog::savingThreadFunction() [LogElement = DB::AsynchronousInsertLogElement]: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/SystemLog.cpp:0: DB::SystemLog::prepareTable() @ 0x00000000117f8a3e 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::SystemLog::savingThreadFunction() @ 0x00000000117f9a95 18. /build/src/Common/SystemLogBase.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000000c750aa8 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:11:57.224567 [ 3691 ] {23b5c81e-665b-4d8d-8645-d1dbf95d22cd} WriteBufferFromS3: Abort multipart upload. Details: bucket test, key content-type.csv, total size 6888890, count 6888890, hidden_size 0, offset 0, with pool: true, prefinalized true, finalized false, upload id ZmYzNmM4NGYtOTg1YS00NzNiLTk1MTItYzQyMjk5ZjMwMjMxLjJkYTQwODdhLTJlMGMtNDE3Ny04YjU1LTBkODIyNmUwYzc4ZXgxNzUwODYwNzE3MjEzMTA4MTQw, upload has finished false 2025.06.25 16:11:57.245034 [ 3691 ] {23b5c81e-665b-4d8d-8645-d1dbf95d22cd} WriteBufferFromS3: Multipart upload has aborted successfully. Details: bucket test, key content-type.csv, total size 6888890, count 6888890, hidden_size 0, offset 0, with pool: true, prefinalized true, finalized false, upload id ZmYzNmM4NGYtOTg1YS00NzNiLTk1MTItYzQyMjk5ZjMwMjMxLjJkYTQwODdhLTJlMGMtNDE3Ny04YjU1LTBkODIyNmUwYzc4ZXgxNzUwODYwNzE3MjEzMTA4MTQw, upload has finished false 2025.06.25 16:11:57.289959 [ 4108 ] {23b5c81e-665b-4d8d-8645-d1dbf95d22cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40588) (comment: 02207_s3_content_type.sh) (in query: INSERT INTO FUNCTION s3('http://localhost:11111/test/content-type.csv', 'test', '[HIDDEN]', 'CSV', 'number UInt64') SETTINGS s3_max_single_part_upload_size = 10000, s3_truncate_on_insert = 1 SELECT number FROM numbers(1000000) SETTINGS s3_max_single_part_upload_size = 10000, s3_truncate_on_insert = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106415a7 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000106413cf 9. /build/contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x00000000106d94eb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106ce6f8 11. /build/src/IO/WriteBufferFromS3.cpp:388: DB::WriteBufferFromS3::preFinalize() @ 0x00000000106c75b3 12. /build/src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::finalizeImpl() @ 0x00000000106c832a 13. /build/src/IO/WriteBuffer.h:132: DB::WriteBuffer::finalize() @ 0x0000000007026330 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageObjectStorageSink::onFinish() @ 0x0000000010599477 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facebc 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 18. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 22. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 23. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:11:57.379248 [ 3998 ] {c8586aa3-5ffd-4337-a108-25f66c04baf2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40586) (comment: 00085_monotonic_evaluation_segfault.sql) (in query: SELECT any(0) FROM test.visits WHERE (toInt32(toDateTime(StartDate))) > 1000000000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:11:57.460682 [ 4108 ] {23b5c81e-665b-4d8d-8645-d1dbf95d22cd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106415a7 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000106413cf 9. /build/contrib/llvm-project/libcxx/include/future:1231: DB::TaskTracker::add(std::function&&) @ 0x00000000106d94eb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000106ce6f8 11. /build/src/IO/WriteBufferFromS3.cpp:388: DB::WriteBufferFromS3::preFinalize() @ 0x00000000106c75b3 12. /build/src/IO/WriteBufferFromS3.cpp:0: DB::WriteBufferFromS3::finalizeImpl() @ 0x00000000106c832a 13. /build/src/IO/WriteBuffer.h:132: DB::WriteBuffer::finalize() @ 0x0000000007026330 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageObjectStorageSink::onFinish() @ 0x0000000010599477 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facebc 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 18. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 22. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 23. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:11:57.680322 [ 3998 ] {c8586aa3-5ffd-4337-a108-25f66c04baf2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:11:58.861219 [ 4370 ] {896f9bae-bbcf-4917-bcd9-7edd26737093} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33080) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT `__table1`.`x` AS `x` FROM `test_9`.`02535_custom_key_mt` AS `__table1` WHERE positiveModulo(sipHash64(`x`), 3) = 0 SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'sipHash64(x)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:58.870811 [ 4370 ] {896f9bae-bbcf-4917-bcd9-7edd26737093} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:11:58.955711 [ 4027 ] {24dca612-5e0a-4069-8dad-91836bf5057b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=727). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40640) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT * FROM 02535_custom_key_mt SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='sipHash64(x)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:11:58.973526 [ 4027 ] {24dca612-5e0a-4069-8dad-91836bf5057b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=727). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:11:59.106800 [ 5174 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33262, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:00.237269 [ 5174 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33276, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/IO/VarInt.h:95: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000000c6c9022 7. /build/src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x0000000012cbd4bd 8. /build/src/Server/TCPHandler.cpp:322: DB::TCPHandler::runImpl() @ 0x0000000012cb47db 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:01.039923 [ 2956 ] {601b2f19-aaee-4f81-a84c-a7a25cf939da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40744) (comment: 02306_window_move_row_number_fix.sql) (in query: SELECT nth_value(NULL, 1048577) OVER (Rows BETWEEN 1023 FOLLOWING AND UNBOUNDED FOLLOWING) ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:01.109317 [ 2956 ] {601b2f19-aaee-4f81-a84c-a7a25cf939da} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=736, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:02.612065 [ 5174 ] {7971903d-c61a-43b5-a70c-9c0c6a1bf824} executeQuery: Code: 57. DB::Exception: Table test_9.`02535_custom_key_mt` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40802) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: CREATE TABLE `02535_custom_key_mt` (`x` String, `y` UInt32) ENGINE = MergeTree ORDER BY cityHash64(x) SETTINGS index_granularity = 53105, min_bytes_for_wide_part = 734259119, ratio_of_defaults_for_sparse_serialization = 0.5137166380882263, replace_long_file_name_to_hash = false, max_file_name_length = 94, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 497760886, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 23668237, merge_max_block_size = 2216, old_parts_lifetime = 158., prefer_fetch_merged_part_size_threshold = 1, 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 = 16806933, concurrent_part_removal_threshold = 18, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 47792, primary_key_compress_block_size = 48029), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:02.612304 [ 2956 ] {77d10fce-6626-4892-a7c8-6091a3aafab6} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_13.t0 (36e0ba6c-02ca-4721-bde4-e7393a4ca840) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40772) (comment: 03262_udf_in_constraint.sh) (in query: INSERT INTO t0(c0) VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:02.614149 [ 2956 ] {77d10fce-6626-4892-a7c8-6091a3aafab6} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_13.t0 (36e0ba6c-02ca-4721-bde4-e7393a4ca840) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:02.653311 [ 5174 ] {7971903d-c61a-43b5-a70c-9c0c6a1bf824} TCPHandler: Code: 57. DB::Exception: Table test_9.`02535_custom_key_mt` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:03.473605 [ 4108 ] {cfe64f23-5801-4723-9fdf-6125d4e85ab4} 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.10505.altinitytest (altinity build)) (from [::1]:40814) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: INSERT INTO 02535_custom_key_mt SELECT toString(number), number % 3 FROM numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:03.491745 [ 4108 ] {cfe64f23-5801-4723-9fdf-6125d4e85ab4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:04.034691 [ 4108 ] {902bda70-18c2-449f-8d4e-394a43e9eff2} executeQuery: Code: 36. DB::Exception: Negative positional argument number -9223372036854775808 is out of bounds. Expected in range [-1, -1]. In scope SELECT 1 GROUP BY -9223372036854775808. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40840) (comment: 03157_negative_positional_arguments_ubsan.sql) (in query: SELECT 1 GROUP BY -9223372036854775808;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&&, String&&) @ 0x000000001106462b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::replaceNodesWithPositionalArguments(std::shared_ptr&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000011043f31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000001105d91f 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5461: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011032a6d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:04.041567 [ 4108 ] {902bda70-18c2-449f-8d4e-394a43e9eff2} TCPHandler: Code: 36. DB::Exception: Negative positional argument number -9223372036854775808 is out of bounds. Expected in range [-1, -1]. In scope SELECT 1 GROUP BY -9223372036854775808. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, long&, unsigned long&&, String&&) @ 0x000000001106462b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::replaceNodesWithPositionalArguments(std::shared_ptr&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x0000000011043f31 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x000000001105d91f 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5461: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011032a6d 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:04.123898 [ 3636 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_1_55_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:04.250619 [ 5174 ] {04e9cc14-a380-48d7-aa15-58712f440deb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40848) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:04.271765 [ 5174 ] {04e9cc14-a380-48d7-aa15-58712f440deb} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:04.812652 [ 5174 ] {76a9ddc6-96b2-4538-adda-0cf0e6b6c4d6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40968) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:04.830551 [ 5174 ] {76a9ddc6-96b2-4538-adda-0cf0e6b6c4d6} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:05.094687 [ 4108 ] {e36beae0-0aea-4f28-ba0c-5ce55bead2bf} executeQuery: Code: 36. DB::Exception: Substitution '\1' in replacement argument is invalid, regexp has only 0 capturing groups. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40962) (comment: 02864_replace_regexp_string_fallback.sql) (in query: -- negative tests -- Even if the fallback is used, invalid substitutions must throw an exception. SELECT 'Hello' AS haystack, 'l' AS needle, '\\1' AS replacement, replaceRegexpOne(materialize(haystack), needle, replacement);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&&) @ 0x000000000b5807ab 4. /build/src/Functions/ReplaceRegexpImpl.h:0: DB::ReplaceRegexpImpl::checkSubstitutions(std::basic_string_view>, int) @ 0x000000000b584eee 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b581b51 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:12:05.105040 [ 4108 ] {e36beae0-0aea-4f28-ba0c-5ce55bead2bf} TCPHandler: Code: 36. DB::Exception: Substitution '\1' in replacement argument is invalid, regexp has only 0 capturing groups. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&&) @ 0x000000000b5807ab 4. /build/src/Functions/ReplaceRegexpImpl.h:0: DB::ReplaceRegexpImpl::checkSubstitutions(std::basic_string_view>, int) @ 0x000000000b584eee 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpOne>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b581b51 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:12:05.212445 [ 4191 ] {5a83e17a-5b7b-4f08-a879-63b626619824} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48426) (comment: 00262_alter_alias.sql) (in query: DROP DATABASE IF EXISTS test_7cno6pgc ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:05.216144 [ 4191 ] {5a83e17a-5b7b-4f08-a879-63b626619824} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:05.338059 [ 4108 ] {e2160c8d-96ca-484c-9116-a55b12262831} executeQuery: Code: 36. DB::Exception: Substitution '\1' in replacement argument is invalid, regexp has only 0 capturing groups. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40962) (comment: 02864_replace_regexp_string_fallback.sql) (in query: SELECT 'Hello' AS haystack, 'l' AS needle, '\\1' AS replacement, replaceRegexpAll(materialize(haystack), needle, replacement);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&&) @ 0x000000000b5807ab 4. /build/src/Functions/ReplaceRegexpImpl.h:0: DB::ReplaceRegexpImpl::checkSubstitutions(std::basic_string_view>, int) @ 0x000000000b58034e 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b57cf1d 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:12:05.340575 [ 4108 ] {e2160c8d-96ca-484c-9116-a55b12262831} TCPHandler: Code: 36. DB::Exception: Substitution '\1' in replacement argument is invalid, regexp has only 0 capturing groups. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&, int&&) @ 0x000000000b5807ab 4. /build/src/Functions/ReplaceRegexpImpl.h:0: DB::ReplaceRegexpImpl::checkSubstitutions(std::basic_string_view>, int) @ 0x000000000b58034e 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::FunctionStringReplace, DB::(anonymous namespace)::NameReplaceRegexpAll>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b57cf1d 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:12:05.358375 [ 5174 ] {24f56e96-387e-487a-b013-219b670fcb30} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40974) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:05.361884 [ 5174 ] {24f56e96-387e-487a-b013-219b670fcb30} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:05.752791 [ 4006 ] {d52109d4-a22f-42d7-a988-f3463f61822e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39974) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 13848191;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:05.784799 [ 4006 ] {d52109d4-a22f-42d7-a988-f3463f61822e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:05.935030 [ 4027 ] {7c773737-3786-4a20-9e73-2448544589e7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40990) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:05.955933 [ 4027 ] {7c773737-3786-4a20-9e73-2448544589e7} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:06.588201 [ 5174 ] {08871b28-4d4a-4666-9a9a-05fd2d5271da} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41024) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:06.606712 [ 5174 ] {08871b28-4d4a-4666-9a9a-05fd2d5271da} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:06.717673 [ 4027 ] {dace5de5-9fca-4f93-a8bf-dfcec3e870c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41016) (comment: 00059_merge_sorting_empty_array_joined.sql) (in query: SELECT CounterID FROM test.visits ARRAY JOIN Goals.ID WHERE CounterID = 942285 ORDER BY CounterID ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:06.759003 [ 4027 ] {dace5de5-9fca-4f93-a8bf-dfcec3e870c4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:07.156710 [ 5174 ] {aec45c1e-296f-4ca4-9e44-ed6cb424bf2b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41054) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:07.167845 [ 5174 ] {aec45c1e-296f-4ca4-9e44-ed6cb424bf2b} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:07.785874 [ 5174 ] {28f556ad-b52b-4f73-9f2c-c0b1f8671460} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41080) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:07.796294 [ 5174 ] {28f556ad-b52b-4f73-9f2c-c0b1f8671460} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:07.803566 [ 4197 ] {26591c27-af8b-4650-b560-8dcf054f9ce5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=28). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41066) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:07.809258 [ 4197 ] {26591c27-af8b-4650-b560-8dcf054f9ce5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=28). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:08.113989 [ 4027 ] {a4e3dcbe-95b6-48dc-af67-99c9704d4eb7} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025342314 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41038) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:08.128900 [ 4027 ] {a4e3dcbe-95b6-48dc-af67-99c9704d4eb7} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025342314 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:08.157416 [ 4006 ] {4459b1f3-4754-47db-a892-17aafab7074c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:39638). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39638) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:08.197655 [ 4006 ] {4459b1f3-4754-47db-a892-17aafab7074c} 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]:39638). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:08.204969 [ 4006 ] {4459b1f3-4754-47db-a892-17aafab7074c} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:39638). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:08.214511 [ 4006 ] {4459b1f3-4754-47db-a892-17aafab7074c} TCPHandler: Client has gone away. 2025.06.25 16:12:08.305545 [ 4197 ] {55fc373f-7071-4e8b-9645-600d781c481d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41098) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:08.317256 [ 4197 ] {55fc373f-7071-4e8b-9645-600d781c481d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:09.002974 [ 4197 ] {55f8f876-cb46-4de5-b8b9-9c910ce54987} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41140) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:09.029264 [ 4197 ] {55f8f876-cb46-4de5-b8b9-9c910ce54987} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:09.710583 [ 4027 ] {ca068ff9-390a-45d6-b5ed-3f7448f5c00a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.030592032 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41128) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:09.724019 [ 4027 ] {ca068ff9-390a-45d6-b5ed-3f7448f5c00a} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.030592032 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:09.797798 [ 6010 ] {42d75daf-2c44-48c9-95da-a890f13553b5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41144) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:09.837225 [ 6010 ] {42d75daf-2c44-48c9-95da-a890f13553b5} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:10.385257 [ 4006 ] {f2e2e081-d07b-4497-9c2e-df5512d12a4c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41164) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:10.416283 [ 4006 ] {f2e2e081-d07b-4497-9c2e-df5512d12a4c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:10.726517 [ 5174 ] {4503daa5-509c-406d-9a7e-f217acec127d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48496) (comment: 03091_analyzer_same_table_name_in_different_databases.sql) (in query: DROP DATABASE IF EXISTS test_6wz335ro ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:10.736324 [ 5174 ] {4503daa5-509c-406d-9a7e-f217acec127d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:11.022132 [ 6010 ] {44b276f6-a16a-4950-82e9-422ab785697f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41180) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:11.049229 [ 6010 ] {44b276f6-a16a-4950-82e9-422ab785697f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:11.177552 [ 4197 ] {d5ba6220-08f1-482d-be0a-afebf8612f5a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.003145831 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41154) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:11.181650 [ 4197 ] {d5ba6220-08f1-482d-be0a-afebf8612f5a} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.003145831 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:11.465613 [ 4197 ] {715aa93c-cbef-4386-9ecd-1647e7b4e88c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41194) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:11.479045 [ 4197 ] {715aa93c-cbef-4386-9ecd-1647e7b4e88c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:11.805448 [ 4197 ] {3c9f826c-da7f-436e-b895-6b40404f1d18} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41212) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:11.825730 [ 4197 ] {3c9f826c-da7f-436e-b895-6b40404f1d18} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:12.209317 [ 4191 ] {cfbffcbb-b7e0-478b-825f-19d45d785c6a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41108) (comment: 00152_insert_different_granularity.sql) (in query: ATTACH TABLE fixed_granularity_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:12.222001 [ 4006 ] {a11c9662-8ec3-4191-8475-30d4db8f404b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41208) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:12.249249 [ 4191 ] {cfbffcbb-b7e0-478b-825f-19d45d785c6a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:12.262721 [ 4006 ] {a11c9662-8ec3-4191-8475-30d4db8f404b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:12.377722 [ 4197 ] {64f532b5-78a4-4990-a544-780cd30d6b8e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41228) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:12.429316 [ 4197 ] {64f532b5-78a4-4990-a544-780cd30d6b8e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:12.832696 [ 4006 ] {1b1a00b6-5697-479c-a7a7-8ee6cf36d576} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.capnp. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41248) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_13-data', CapnProto) select * from numbers(10) settings output_format_schema='/tmp/schema.capnp'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e36ddf 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012e39aa5 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:12.849468 [ 4006 ] {1b1a00b6-5697-479c-a7a7-8ee6cf36d576} TCPHandler: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.capnp. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e36ddf 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012e39aa5 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:12.914968 [ 4108 ] {602d62df-9a20-4e1f-a8cc-3ade6e224d7d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41272) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:12.930782 [ 4108 ] {602d62df-9a20-4e1f-a8cc-3ade6e224d7d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:13.509266 [ 4006 ] {dec8ac5e-edc0-421c-ba83-e02420663a92} executeQuery: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.capnp not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41284) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_13-data', CapnProto) select * from numbers(10) settings output_format_schema='../../schema.capnp'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e37892 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012e39aa5 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:13.514255 [ 4108 ] {f164e008-dbc5-4ff7-acee-3be5ad087ec3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41288) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:13.532540 [ 4006 ] {dec8ac5e-edc0-421c-ba83-e02420663a92} TCPHandler: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.capnp not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e37892 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012e39aa5 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:13.546857 [ 4108 ] {f164e008-dbc5-4ff7-acee-3be5ad087ec3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:14.091284 [ 4197 ] {b1fb55c7-8d53-45dd-ac5c-49d7b2b64d95} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.343468314 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41240) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:14.118899 [ 4006 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39654, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.131140 [ 4191 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40172, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.132618 [ 4197 ] {b1fb55c7-8d53-45dd-ac5c-49d7b2b64d95} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.343468314 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:14.247957 [ 6010 ] {87fe22d7-9e91-4185-bf55-e68d7c5aa44a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:43884). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43884) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.248075 [ 6379 ] {1e7fc6d5-2ee8-44ba-83c8-3f8abd0a8afe} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:56146). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56146) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.248045 [ 4108 ] {115a3001-c504-4333-a85c-d86cfd7fda5e} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:52412). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52412) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.252151 [ 4108 ] {115a3001-c504-4333-a85c-d86cfd7fda5e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:52412). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.261043 [ 4108 ] {115a3001-c504-4333-a85c-d86cfd7fda5e} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:52412). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.263254 [ 6010 ] {87fe22d7-9e91-4185-bf55-e68d7c5aa44a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:43884). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.268331 [ 6010 ] {87fe22d7-9e91-4185-bf55-e68d7c5aa44a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:43884). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.274076 [ 6010 ] {87fe22d7-9e91-4185-bf55-e68d7c5aa44a} TCPHandler: Client has gone away. 2025.06.25 16:12:14.284564 [ 5174 ] {d5eb4465-126b-4006-9457-a439a4fa4a72} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:58594). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58594) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.300344 [ 6379 ] {1e7fc6d5-2ee8-44ba-83c8-3f8abd0a8afe} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:56146). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.305095 [ 6379 ] {1e7fc6d5-2ee8-44ba-83c8-3f8abd0a8afe} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:56146). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.327898 [ 4108 ] {115a3001-c504-4333-a85c-d86cfd7fda5e} TCPHandler: Client has gone away. 2025.06.25 16:12:14.331657 [ 5174 ] {d5eb4465-126b-4006-9457-a439a4fa4a72} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:58594). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:14.332996 [ 5174 ] {d5eb4465-126b-4006-9457-a439a4fa4a72} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:58594). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:14.381464 [ 6379 ] {1e7fc6d5-2ee8-44ba-83c8-3f8abd0a8afe} TCPHandler: Client has gone away. 2025.06.25 16:12:14.385037 [ 5174 ] {d5eb4465-126b-4006-9457-a439a4fa4a72} TCPHandler: Client has gone away. 2025.06.25 16:12:14.387261 [ 6398 ] {e1c5ba91-f240-4c20-ba8b-c580fb0c43cd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41302) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:14.423204 [ 6398 ] {e1c5ba91-f240-4c20-ba8b-c580fb0c43cd} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:15.071420 [ 4006 ] {3d079609-e74c-4559-916b-457dd696bff1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42276) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:15.118409 [ 4006 ] {3d079609-e74c-4559-916b-457dd696bff1} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:15.726798 [ 4197 ] {2879a6ef-7b23-4111-9d5c-aba8e71ee897} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.094737186 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42266) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:15.755897 [ 6398 ] {fedae354-0844-4bc2-93fd-58f4f287d96b} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:48696). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48696) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:15.756268 [ 4191 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49390, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:15.757567 [ 4197 ] {2879a6ef-7b23-4111-9d5c-aba8e71ee897} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.094737186 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:15.757630 [ 3998 ] {ec0fa621-7368-4577-ab99-13de2b149593} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42282) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:15.760201 [ 4108 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40884, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:15.767926 [ 6398 ] {fedae354-0844-4bc2-93fd-58f4f287d96b} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:48696). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:15.781139 [ 6398 ] {fedae354-0844-4bc2-93fd-58f4f287d96b} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:48696). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:15.784441 [ 3998 ] {ec0fa621-7368-4577-ab99-13de2b149593} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:15.788772 [ 6398 ] {fedae354-0844-4bc2-93fd-58f4f287d96b} TCPHandler: Client has gone away. 2025.06.25 16:12:15.813591 [ 4006 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43366, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:16.166664 [ 4006 ] {f1cdf697-bbfc-4d97-be24-15dc162b16d1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42294) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:16.169048 [ 4006 ] {f1cdf697-bbfc-4d97-be24-15dc162b16d1} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:16.651084 [ 4006 ] {50024eac-c5d1-4aff-809a-6ff0916567c4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42302) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:16.665599 [ 4006 ] {50024eac-c5d1-4aff-809a-6ff0916567c4} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.091650 [ 4006 ] {31e4a50f-3fb5-473d-8678-88e1179c90b7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42310) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.105347 [ 4006 ] {31e4a50f-3fb5-473d-8678-88e1179c90b7} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.111371 [ 4197 ] {37f32184-6d26-4fd2-b674-940f36234fbb} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.014328577 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42288) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:17.127711 [ 4197 ] {37f32184-6d26-4fd2-b674-940f36234fbb} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.014328577 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:17.527924 [ 4197 ] {491ebee7-4385-4c21-a6a6-16051cd4c997} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='y', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.558230 [ 4197 ] {491ebee7-4385-4c21-a6a6-16051cd4c997} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'y', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.928965 [ 4197 ] {337a8e62-196d-4cb6-a7b5-6b04b8f6461f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42338) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:17.963479 [ 4197 ] {337a8e62-196d-4cb6-a7b5-6b04b8f6461f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:18.619845 [ 6836 ] {0b5b78a6-7dd1-4e2d-980e-55e32f057602} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42354) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:18.651394 [ 6836 ] {0b5b78a6-7dd1-4e2d-980e-55e32f057602} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:18.683977 [ 4006 ] {85d99d12-e1c0-4145-bab2-0ce5f534c78e} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.144714937 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42326) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:18.728494 [ 6010 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49408, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:18.732002 [ 2952 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40366, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:18.738006 [ 4006 ] {85d99d12-e1c0-4145-bab2-0ce5f534c78e} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.144714937 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:19.073589 [ 3998 ] {19536b59-2412-4146-8be8-67796d49898b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42360) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:19.083261 [ 3998 ] {19536b59-2412-4146-8be8-67796d49898b} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:19.518653 [ 6665 ] {74fe30a2-ad4c-42da-a61e-1583a4413cfc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42392) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:19.557305 [ 6665 ] {74fe30a2-ad4c-42da-a61e-1583a4413cfc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:19.611239 [ 3998 ] {5e1d8a17-3a1a-46c0-9f31-7cd8c76e6542} executeQuery: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.proto. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42382) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_13-data', Protobuf) select * from numbers(10) settings output_format_schema='/tmp/schema.proto'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e3833f 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012f4c227 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:19.641515 [ 3998 ] {5e1d8a17-3a1a-46c0-9f31-7cd8c76e6542} TCPHandler: Code: 36. DB::Exception: Absolute path in the 'output_format_schema' setting is prohibited: /tmp/schema.proto. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e3833f 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012f4c227 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:20.068654 [ 3998 ] {a2a9d3a0-7eda-4776-a922-4b0fdf966f3a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42420) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:20.092677 [ 3998 ] {a2a9d3a0-7eda-4776-a922-4b0fdf966f3a} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:20.467964 [ 5054 ] {f18b0130-4922-48fe-9497-69f9f2ae9c0e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40590) (comment: 03143_asof_join_ddb_long.sql) (in query: SELECT SUM(value), COUNT(*) FROM skewed_probe ASOF JOIN build USING (key, begin) ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:20.519252 [ 5054 ] {f18b0130-4922-48fe-9497-69f9f2ae9c0e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:20.567344 [ 2952 ] {87331455-85b0-40a8-b20c-c4d588100c2d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.440098601 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42366) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:20.587662 [ 3998 ] {01911001-5980-4934-8a41-c9cd8e08c365} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42448) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:20.599957 [ 6398 ] {8e09f483-f03d-4934-85ea-bfe03424613a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40376). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40376) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:20.605249 [ 6665 ] {05637c4b-e89f-4649-86b8-3aa068d9a400} executeQuery: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.proto not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42428) (comment: 02817_structure_to_schema.sh) (in query: insert into function file('02817_structure_to_schema_test_13-data', Protobuf) select * from numbers(10) settings output_format_schema='../../schema.proto'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e38df2 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012f4c227 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:20.607234 [ 6398 ] {8e09f483-f03d-4934-85ea-bfe03424613a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40376). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.614151 [ 3998 ] {01911001-5980-4934-8a41-c9cd8e08c365} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y)', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:20.616895 [ 6398 ] {8e09f483-f03d-4934-85ea-bfe03424613a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40376). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:12:20.620222 [ 6398 ] {8e09f483-f03d-4934-85ea-bfe03424613a} TCPHandler: Client has gone away. 2025.06.25 16:12:20.621144 [ 4191 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49424, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.646304 [ 6665 ] {05637c4b-e89f-4649-86b8-3aa068d9a400} TCPHandler: Code: 36. DB::Exception: Path in the 'format_schema' setting shouldn't go outside the 'format_schema_path' directory: /var/lib/clickhouse/format_schemas/ (../../schema.proto not in /var/lib/clickhouse/format_schemas/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Formats/FormatSchemaInfo.cpp:0: DB::MaybeAutogeneratedFormatSchemaInfo::MaybeAutogeneratedFormatSchemaInfo(DB::FormatSettings const&, String const&, DB::Block const&, bool) @ 0x0000000012e38df2 5. /build/contrib/llvm-project/libcxx/include/new:246: std::shared_ptr std::__function::__policy_invoker (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>::__call_impl (DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&)>>(std::__function::__policy_storage const*, DB::WriteBuffer&, DB::Block const&, DB::FormatSettings const&) @ 0x0000000012f4c227 6. /build/src/Formats/FormatFactory.cpp:552: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce43ca 7. /build/src/Formats/FormatFactory.cpp:527: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce38f4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageFileSink::initialize() @ 0x000000001226d810 9. /build/src/Storages/StorageFile.cpp:1771: DB::StorageFileSink::StorageFileSink(std::shared_ptr const&, String const&, std::unique_lock&&, int, bool, String, String const&, DB::CompressionMethod, std::optional const&, String, std::shared_ptr const&, int) @ 0x000000001226e2c2 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageFileSink* std::construct_at[abi:v15007] const&, String, std::unique_lock, int&, bool&, String&, String&, DB::CompressionMethod, std::optional&, String&, std::shared_ptr&, int&, DB::StorageFileSink*>(DB::StorageFileSink*, std::shared_ptr const&, String&&, std::unique_lock&&, int&, bool&, String&, String&, DB::CompressionMethod&&, std::optional&, String&, std::shared_ptr&, int&) @ 0x000000001226dfa7 11. /build/contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000012261ec3 12. /build/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&) @ 0x00000000130561e2 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 14. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 15. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 16. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:20.660769 [ 6010 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48718, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.671832 [ 4108 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:49688, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.685107 [ 5174 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33310, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.685259 [ 6836 ] {96d35e66-458b-46e0-9427-8c8c91d6003a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:60130). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60130) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.708066 [ 6836 ] {96d35e66-458b-46e0-9427-8c8c91d6003a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:60130). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.711171 [ 4006 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40906, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.713826 [ 4197 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43384, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.717130 [ 6836 ] {96d35e66-458b-46e0-9427-8c8c91d6003a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:60130). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.725813 [ 2952 ] {87331455-85b0-40a8-b20c-c4d588100c2d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.440098601 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:12:20.730392 [ 6836 ] {96d35e66-458b-46e0-9427-8c8c91d6003a} TCPHandler: Client has gone away. 2025.06.25 16:12:20.747189 [ 6985 ] {f7dec0d0-f0eb-4935-9ba7-5938f8f6af07} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:44708). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44708) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.749153 [ 2956 ] {4df1710f-b753-401a-89a1-f7f08c0535c0} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:38596). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38596) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.760955 [ 6985 ] {f7dec0d0-f0eb-4935-9ba7-5938f8f6af07} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:44708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.769833 [ 6985 ] {f7dec0d0-f0eb-4935-9ba7-5938f8f6af07} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:44708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.774021 [ 2956 ] {4df1710f-b753-401a-89a1-f7f08c0535c0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:38596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:20.775432 [ 6985 ] {f7dec0d0-f0eb-4935-9ba7-5938f8f6af07} TCPHandler: Client has gone away. 2025.06.25 16:12:20.777146 [ 2956 ] {4df1710f-b753-401a-89a1-f7f08c0535c0} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:38596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:20.782786 [ 2956 ] {4df1710f-b753-401a-89a1-f7f08c0535c0} TCPHandler: Client has gone away. 2025.06.25 16:12:21.090131 [ 2952 ] {6ce1ad7c-5ddc-48b5-9511-defb98eb1bd9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42484) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:21.113133 [ 2952 ] {6ce1ad7c-5ddc-48b5-9511-defb98eb1bd9} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:21.475102 [ 6665 ] {9b050d15-7b44-4707-83d8-d017a2a085f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42488) (comment: 00173_group_by_use_nulls.sql) (in query: SELECT CounterID AS k, quantileBFloat16(0.5)(ResolutionWidth) FROM remote('127.0.0.{1,2}', test, hits) GROUP BY k ORDER BY count() DESC, CounterID ASC LIMIT 10 SETTINGS group_by_use_nulls = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:21.481071 [ 6665 ] {9b050d15-7b44-4707-83d8-d017a2a085f6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:21.511674 [ 4006 ] {0d298878-7217-43c8-a631-8328b648cdbb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42510) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:21.516410 [ 4006 ] {0d298878-7217-43c8-a631-8328b648cdbb} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:21.937005 [ 5174 ] {b003023d-bd51-4725-8c16-4b9df8fe8c8d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42518) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_sampling', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:21.943662 [ 5174 ] {b003023d-bd51-4725-8c16-4b9df8fe8c8d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_sampling', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:22.447829 [ 5054 ] {54598509-bfcf-4bb2-9c51-b1b46b81e47f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50556) (comment: 03143_asof_join_ddb_long.sql) (in query: DROP DATABASE IF EXISTS test_wucazjic ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:22.449111 [ 5054 ] {54598509-bfcf-4bb2-9c51-b1b46b81e47f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:22.493558 [ 6398 ] {0991a94b-e276-4c9a-b214-77392129e39a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42548) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=1, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:22.499228 [ 6398 ] {0991a94b-e276-4c9a-b214-77392129e39a} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 1, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:22.553348 [ 5174 ] {9a7b2c40-baad-4292-9645-42f49ea307ca} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50572) (comment: 03143_asof_join_ddb_long.sql) (in query: DROP DATABASE IF EXISTS test_wucazjic ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:22.554830 [ 5174 ] {9a7b2c40-baad-4292-9645-42f49ea307ca} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:22.611328 [ 6398 ] {e2e1b62f-db81-4be8-b036-bf2f57b4e9ee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50582) (comment: 03143_asof_join_ddb_long.sql) (in query: DROP DATABASE IF EXISTS test_wucazjic ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:22.615306 [ 6398 ] {e2e1b62f-db81-4be8-b036-bf2f57b4e9ee} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:22.816842 [ 2956 ] {5b116b00-0728-4d3f-bece-58d81ac14eee} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42572) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=2, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:22.825942 [ 2956 ] {5b116b00-0728-4d3f-bece-58d81ac14eee} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 2, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:23.157657 [ 6836 ] {811cfb1b-ba83-4027-b6fe-3f3314d36b3c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42608) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT y, count() FROM 02535_custom_key_mt GROUP BY y ORDER BY y SETTINGS max_parallel_replicas=3, enable_parallel_replicas='1' , parallel_replicas_mode ='custom_key_range', parallel_replicas_custom_key='cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree=1 , cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:23.209647 [ 6836 ] {811cfb1b-ba83-4027-b6fe-3f3314d36b3c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'y' in scope SELECT y, count() FROM `02535_custom_key_mt` GROUP BY y ORDER BY y ASC SETTINGS max_parallel_replicas = 3, enable_parallel_replicas = '1', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key = 'cityHash64(y) + 1', parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost'. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:23.842164 [ 6985 ] {ac3ce67d-4eda-495b-af8b-f115ea1235b1} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (y) using identifier 'y' cannot be resolved from left table expression. In scope SELECT count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) AS t1 INNER JOIN `02535_custom_key_mt` USING (y). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42666) (comment: 02535_max_parallel_replicas_custom_key_mt.sh) (in query: SELECT count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), 02535_custom_key_mt) as t1 JOIN 02535_custom_key_mt USING y), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000011066c4b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110635e3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:23.869701 [ 6985 ] {ac3ce67d-4eda-495b-af8b-f115ea1235b1} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (y) using identifier 'y' cannot be resolved from left table expression. In scope SELECT count() FROM cluster(test_cluster_one_shard_three_replicas_localhost, currentDatabase(), `02535_custom_key_mt`) AS t1 INNER JOIN `02535_custom_key_mt` USING (y). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000011066c4b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110635e3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:24.310094 [ 6379 ] {867fc718-12e8-494c-b329-dd6e4ebcd8fc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=720). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54442) (comment: 00159_parallel_formatting_csv_and_friends.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:24.327576 [ 6379 ] {867fc718-12e8-494c-b329-dd6e4ebcd8fc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=720). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:26.590210 [ 6155 ] {497e77b9-9355-444d-977e-95b9d1d3e13a} executeQuery: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54566) (comment: 02047_client_exception.expect) (in query: INSERT INTO test_02047 SELECT 'f'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 13. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000010fc4a48 20. /build/src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc53a1 21. /build/src/Interpreters/ActionsDAG.cpp:1554: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd247f 22. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 23. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:12:26.598078 [ 6155 ] {497e77b9-9355-444d-977e-95b9d1d3e13a} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'f' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `'f'` to destination column s. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 13. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000010fc4a48 20. /build/src/Interpreters/ActionsDAG.cpp:286: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000010fc53a1 21. /build/src/Interpreters/ActionsDAG.cpp:1554: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd247f 22. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 23. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:12:26.626994 [ 6836 ] {e4f584f5-91ef-4a69-a92d-355676e0e3c0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54596) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a45f6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4048 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4352 12. /build/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*) @ 0x000000001190d9b7 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:26.649146 [ 6836 ] {e4f584f5-91ef-4a69-a92d-355676e0e3c0} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a45f6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4048 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4352 12. /build/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*) @ 0x000000001190d9b7 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:27.003885 [ 5054 ] {08a1142e-c838-4a15-b3f9-75b08d20862e} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]'): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0): While collecting data of table test_f8hhnerk.data for backup. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:106: DB::readStringUntilEOF(String&, DB::ReadBuffer&) @ 0x000000000c6b185d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::BackupEntryFromSmallFile::BackupEntryFromSmallFile(std::shared_ptr const&, String const&, DB::ReadSettings const&, bool) @ 0x000000001230250c 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const::$_0::operator()(String const&) const @ 0x00000000126c56e8 16. /build/contrib/llvm-project/libcxx/include/__hash_table:454: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const @ 0x00000000126c4b4b 17. /build/src/Storages/MergeTree/MergeTreeData.cpp:5461: DB::MergeTreeData::backupParts(std::vector, std::allocator>> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, std::shared_ptr const&) @ 0x00000000127c6340 18. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::StorageMergeTree::backupData(DB::BackupEntriesCollector&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000012a9a4f1 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupEntriesCollector::makeBackupEntriesForTableData(DB::QualifiedTableName const&) @ 0x00000000108b7720 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010404f5a 21. /build/contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x000000000cba7757 22. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 23. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 24. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:27.272511 [ 5054 ] {08a1142e-c838-4a15-b3f9-75b08d20862e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0): While collecting data of table test_f8hhnerk.data for backup. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54500) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:106: DB::readStringUntilEOF(String&, DB::ReadBuffer&) @ 0x000000000c6b185d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::BackupEntryFromSmallFile::BackupEntryFromSmallFile(std::shared_ptr const&, String const&, DB::ReadSettings const&, bool) @ 0x000000001230250c 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const::$_0::operator()(String const&) const @ 0x00000000126c56e8 16. /build/contrib/llvm-project/libcxx/include/__hash_table:454: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const @ 0x00000000126c4b4b 17. /build/src/Storages/MergeTree/MergeTreeData.cpp:5461: DB::MergeTreeData::backupParts(std::vector, std::allocator>> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, std::shared_ptr const&) @ 0x00000000127c6340 18. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::StorageMergeTree::backupData(DB::BackupEntriesCollector&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000012a9a4f1 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupEntriesCollector::makeBackupEntriesForTableData(DB::QualifiedTableName const&) @ 0x00000000108b7720 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010404f5a 21. /build/contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x000000000cba7757 22. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 23. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 24. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:12:27.336694 [ 5054 ] {08a1142e-c838-4a15-b3f9-75b08d20862e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0): While collecting data of table test_f8hhnerk.data for backup. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:106: DB::readStringUntilEOF(String&, DB::ReadBuffer&) @ 0x000000000c6b185d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: DB::BackupEntryFromSmallFile::BackupEntryFromSmallFile(std::shared_ptr const&, String const&, DB::ReadSettings const&, bool) @ 0x000000001230250c 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const::$_0::operator()(String const&) const @ 0x00000000126c56e8 16. /build/contrib/llvm-project/libcxx/include/__hash_table:454: DB::DataPartStorageOnDiskBase::backup(DB::MergeTreeDataPartChecksums const&, std::unordered_set, std::equal_to, std::allocator> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, bool, std::vector>, std::allocator>>>&, std::map, std::shared_ptr, std::less>, std::allocator const, std::shared_ptr>>>*, bool, bool) const @ 0x00000000126c4b4b 17. /build/src/Storages/MergeTree/MergeTreeData.cpp:5461: DB::MergeTreeData::backupParts(std::vector, std::allocator>> const&, String const&, DB::BackupSettings const&, DB::ReadSettings const&, std::shared_ptr const&) @ 0x00000000127c6340 18. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::StorageMergeTree::backupData(DB::BackupEntriesCollector&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000012a9a4f1 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupEntriesCollector::makeBackupEntriesForTableData(DB::QualifiedTableName const&) @ 0x00000000108b7720 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010404f5a 21. /build/contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x000000000cba7757 22. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 23. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 24. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:12:28.140160 [ 6986 ] {9296c6b6-c9c0-4f40-854c-9bca2a7993fc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54516) (comment: 00013_sorting_of_nested.sql) (in query: SELECT ParsedParams.Key1 FROM test.visits FINAL WHERE VisitID != 0 AND notEmpty(ParsedParams.Key1) ORDER BY VisitID LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddb2e 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:28.429569 [ 4191 ] {93d86f10-dae8-44f6-b4dd-cbf025793a33} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:12:28.474016 [ 4191 ] {93d86f10-dae8-44f6-b4dd-cbf025793a33} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54660) (comment: 02428_parameterized_view.sh) (in query: CREATE TABLE test_02428_Catalog (`Name` String, `Price` UInt64, `Quantity` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02428_parameterized_view_test_11/parameterized_view', 'r1') ORDER BY Name SETTINGS index_granularity = 43449, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8693392276763916, 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 = 126527738, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 20558095, merge_max_block_size = 3585, old_parts_lifetime = 109., prefer_fetch_merged_part_size_threshold = 2093655777, 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 = 14112612, concurrent_part_removal_threshold = 38, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 85484, primary_key_compress_block_size = 12175), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:28.496263 [ 4191 ] {93d86f10-dae8-44f6-b4dd-cbf025793a33} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:28.852180 [ 6155 ] {adef35c1-b63f-4153-b6a2-cd7eb7666394} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:28.855265 [ 6155 ] {adef35c1-b63f-4153-b6a2-cd7eb7666394} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54652) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:28.859172 [ 6155 ] {adef35c1-b63f-4153-b6a2-cd7eb7666394} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:28.921636 [ 6398 ] {c5af1a10-2dcc-4b59-bc2c-667741428a84} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54678) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_Catalog VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:28.923574 [ 6398 ] {c5af1a10-2dcc-4b59-bc2c-667741428a84} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:29.051149 [ 6986 ] {9296c6b6-c9c0-4f40-854c-9bca2a7993fc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddb2e 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:29.298044 [ 6398 ] {231ea1ca-3a8f-416c-a33f-e0743c2b6bf3} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54686) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_Catalog VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:29.321654 [ 6398 ] {231ea1ca-3a8f-416c-a33f-e0743c2b6bf3} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:29.805674 [ 4191 ] {cdba052f-5e3c-4cb9-88fd-2ee5d749ddf7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54666) (comment: 01601_custom_tld.gen.sql) (in query: select firstSignificantSubdomainCustom('foo.kernel.biz.ss', 'public_suffix_list');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:29.813304 [ 4191 ] {cdba052f-5e3c-4cb9-88fd-2ee5d749ddf7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:29.845384 [ 3998 ] {9644964f-6203-4c6b-acc2-6ae5323c06c1} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54718) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_Catalog VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:29.899783 [ 3998 ] {9644964f-6203-4c6b-acc2-6ae5323c06c1} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:30.628757 [ 5056 ] {4f6f02fc-e01f-4ea6-97f7-374ac0d862a9} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1/.backup: While executing S3Source. (S3_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54680) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: SELECT replace(line, 'testtest', 'INVALID_PASSWORD') FROM s3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1/.backup', 'test', '[HIDDEN]', 'LineAsString')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v9::basic_format_string::type, fmt::v9::type_identity::type>, String const&, unsigned long&&) @ 0x000000001064296e 3. /build/src/IO/S3/getObjectInfo.cpp:0: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x0000000010642b58 4. /build/src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:0: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x00000000106390e8 5. /build/src/Disks/ObjectStorages/IObjectStorage.h:53: DB::StorageObjectStorageSource::KeysIterator::nextImpl(unsigned long) @ 0x00000000105a0cee 6. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x000000001059da39 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000001059cc1c 8. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:273: DB::StorageObjectStorageSource::createReader() @ 0x000000001059bd2c 9. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:167: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000001059bb67 10. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::generate() @ 0x000000001059bf7f 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:30.638925 [ 5056 ] {4f6f02fc-e01f-4ea6-97f7-374ac0d862a9} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1/.backup: While executing S3Source. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v9::basic_format_string::type, fmt::v9::type_identity::type>, String const&, unsigned long&&) @ 0x000000001064296e 3. /build/src/IO/S3/getObjectInfo.cpp:0: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x0000000010642b58 4. /build/src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:0: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x00000000106390e8 5. /build/src/Disks/ObjectStorages/IObjectStorage.h:53: DB::StorageObjectStorageSource::KeysIterator::nextImpl(unsigned long) @ 0x00000000105a0cee 6. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x000000001059da39 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000001059cc1c 8. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:273: DB::StorageObjectStorageSource::createReader() @ 0x000000001059bd2c 9. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:167: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000001059bb67 10. /build/src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::generate() @ 0x000000001059bf7f 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:30.756179 [ 4197 ] {9b9e9317-c0b4-40fc-87b1-804e8d5b9a54} 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]:40916). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40916) (comment: 00173_group_by_use_nulls.sql) (in query: SELECT `__table1`.`CounterID` AS `k`, quantileBFloat16(0.5)(`__table1`.`ResolutionWidth`) AS `quantileBFloat16(0.5)(ResolutionWidth)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:30.758654 [ 4197 ] {9b9e9317-c0b4-40fc-87b1-804e8d5b9a54} 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]:40916). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:30.759463 [ 4197 ] {9b9e9317-c0b4-40fc-87b1-804e8d5b9a54} 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]:40916). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:30.776542 [ 4197 ] {9b9e9317-c0b4-40fc-87b1-804e8d5b9a54} TCPHandler: Client has gone away. 2025.06.25 16:12:30.836559 [ 2952 ] {4c9f0001-ae13-4b45-94e1-26b38ce773a4} 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]:43398). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43398) (comment: 00173_group_by_use_nulls.sql) (in query: SELECT `__table1`.`CounterID` AS `k`, quantileBFloat16(0.5)(`__table1`.`ResolutionWidth`) AS `quantileBFloat16(0.5)(ResolutionWidth)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf834 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:30.894837 [ 2952 ] {4c9f0001-ae13-4b45-94e1-26b38ce773a4} 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]:43398). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:30.899879 [ 2952 ] {4c9f0001-ae13-4b45-94e1-26b38ce773a4} 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]:43398). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf834 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:12:30.919759 [ 2952 ] {4c9f0001-ae13-4b45-94e1-26b38ce773a4} TCPHandler: Client has gone away. 2025.06.25 16:12:31.344431 [ 6155 ] {7e4635f9-7bcb-4ee0-95f3-23fd8eb2634f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(20, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54752) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv1(price=20)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:31.365279 [ 6155 ] {7e4635f9-7bcb-4ee0-95f3-23fd8eb2634f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(20, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:31.956221 [ 6155 ] {c4233276-078b-4e78-acf3-e1705b02886a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(20, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54770) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM `test_02428_pv1`(price=20)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:31.983054 [ 6155 ] {c4233276-078b-4e78-acf3-e1705b02886a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(20, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:32.250285 [ 5056 ] {0bae6eb9-c570-4874-8abb-bb61c0292907} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:32.251607 [ 4191 ] {192ff3f4-5e2a-494b-8254-2114a6ecd3c0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Price' in scope SELECT Price FROM test_02428_pv1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54786) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:32.255287 [ 5056 ] {0bae6eb9-c570-4874-8abb-bb61c0292907} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54750) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:32.281779 [ 4191 ] {192ff3f4-5e2a-494b-8254-2114a6ecd3c0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Price' in scope SELECT Price FROM test_02428_pv1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:32.298432 [ 5056 ] {0bae6eb9-c570-4874-8abb-bb61c0292907} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:32.617382 [ 5056 ] {53020296-44d4-4241-b848-773151519608} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54796) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv1(price = _CAST(10, 'UInt64'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:32.621261 [ 5056 ] {53020296-44d4-4241-b848-773151519608} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:33.017148 [ 5056 ] {191c8e84-c834-453c-b5d5-bda1506d98e0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(50, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54828) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv1(price = 50) LIMIT _CAST(1, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:33.026506 [ 5056 ] {191c8e84-c834-453c-b5d5-bda1506d98e0} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = _CAST(50, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:33.460478 [ 5056 ] {30c8b58e-4549-46ed-8aaa-788cc684cce6} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54838) (comment: 02428_parameterized_view.sh) (in query: DETACH TABLE test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8e24 5. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 8. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:33.463205 [ 5056 ] {30c8b58e-4549-46ed-8aaa-788cc684cce6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8e24 5. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 8. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:33.737121 [ 6155 ] {33dd50c6-9595-4911-9628-b1e176cfc6c8} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000010642892 3. /build/src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000010957ef7 4. /build/contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000010957b44 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x00000000109458de 6. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 10. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 14. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 16. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:33.743770 [ 6155 ] {33dd50c6-9595-4911-9628-b1e176cfc6c8} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54804) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000010642892 3. /build/src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000010957ef7 4. /build/contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000010957b44 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x00000000109458de 6. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 10. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 14. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 16. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:33.765396 [ 6155 ] {33dd50c6-9595-4911-9628-b1e176cfc6c8} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000010642892 3. /build/src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000010957ef7 4. /build/contrib/llvm-project/libcxx/include/vector:553: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000010957b44 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x00000000109458de 6. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 10. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 14. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 16. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:33.929841 [ 5056 ] {5d4122ff-3d21-43c2-8f8e-51e749d3e3f1} executeQuery: Code: 57. DB::Exception: Table test_11.test_02428_pv1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000011 */ ATTACH TABLE test_11.test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555c66 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:33.958956 [ 5056 ] {5d4122ff-3d21-43c2-8f8e-51e749d3e3f1} executeQuery: Code: 57. DB::Exception: Table test_11.test_02428_pv1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54860) (comment: 02428_parameterized_view.sh) (in query: ATTACH TABLE test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555c66 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:33.981459 [ 5056 ] {5d4122ff-3d21-43c2-8f8e-51e749d3e3f1} TCPHandler: Code: 57. DB::Exception: Table test_11.test_02428_pv1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011555c66 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:34.724385 [ 4191 ] {76ce4f49-579f-4bd5-ad4d-b4c302d0d5db} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist: While processing SELECT * FROM test_02428_pv1(price = 10). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43452) (comment: 02428_parameterized_view.sh) (in query: EXPLAIN SYNTAX SELECT * from test_02428_pv1(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::JoinedTables::getLeftTableStorage() @ 0x00000000116ba719 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011607a04 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116071f1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000001169d2b5 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001169b6cc 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001169df14 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x00000000110e5ad3 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::JoinedTables::getLeftTableStorage() @ 0x00000000116ba40d 15. /build/src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011607a04 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116070cc 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011606e31 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157f2bb 19. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f570 20. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 21. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157980e 23. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:12:34.745332 [ 4191 ] {76ce4f49-579f-4bd5-ad4d-b4c302d0d5db} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist: While processing SELECT * FROM test_02428_pv1(price = 10). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::JoinedTables::getLeftTableStorage() @ 0x00000000116ba719 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011607a04 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116071f1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x000000001169d2b5 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:154: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001169b6cc 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001169df14 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::executeTableFunction(std::shared_ptr const&, DB::ASTSelectQuery const*) @ 0x00000000110e5ad3 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::JoinedTables::getLeftTableStorage() @ 0x00000000116ba40d 15. /build/src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011607a04 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116070cc 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011606e31 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157f2bb 19. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f570 20. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 21. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157980e 23. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:12:35.193502 [ 5056 ] {9aac387d-0299-4e2f-8327-0c2ebd865c39} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_4', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:35.222901 [ 5056 ] {9aac387d-0299-4e2f-8327-0c2ebd865c39} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54872) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_4', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:35.242890 [ 5056 ] {9aac387d-0299-4e2f-8327-0c2ebd865c39} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:35.309056 [ 4191 ] {09b90536-5d56-46c0-9371-a62170bbc827} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43456) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_pv1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000102e465a 5. /build/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&) @ 0x00000000130561e2 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 7. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa407 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbb81 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:35.319680 [ 4191 ] {09b90536-5d56-46c0-9371-a62170bbc827} TCPHandler: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000102e465a 5. /build/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&) @ 0x00000000130561e2 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 7. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115fa407 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbb81 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:35.691788 [ 3998 ] {d726a7fe-77fd-4362-8b9c-15fc5c988aaa} executeQuery: Code: 46. DB::Exception: Unknown table function pv123. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43494) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM pv123(price=20)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:35.713028 [ 3998 ] {d726a7fe-77fd-4362-8b9c-15fc5c988aaa} TCPHandler: Code: 46. DB::Exception: Unknown table function pv123. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:36.138867 [ 3998 ] {a72078d9-b275-4dbf-8372-c2771276fb6c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43506) (comment: 02428_parameterized_view.sh) (in query: CREATE VIEW test_02428_v1 AS SELECT * FROM test_02428_Catalog WHERE Price=10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155193c 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:36.159005 [ 3998 ] {a72078d9-b275-4dbf-8372-c2771276fb6c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE Price = 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155193c 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:36.602034 [ 3998 ] {a724bb8f-105f-4d0f-b290-80e32483be3a} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_v1. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43516) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_v1(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:36.611725 [ 3998 ] {a724bb8f-105f-4d0f-b290-80e32483be3a} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_v1. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:36.755587 [ 4191 ] {5d627885-c9fe-4dd8-8521-8d321bdb1c47} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:36.775821 [ 4191 ] {5d627885-c9fe-4dd8-8521-8d321bdb1c47} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43478) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data FROM S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:36.784528 [ 4191 ] {5d627885-c9fe-4dd8-8521-8d321bdb1c47} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:37.328878 [ 2956 ] {659a76f7-32da-4d88-96f9-cd1a9ca53a47} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42578) (comment: 00167_settings_inside_query.sql) (in query: SELECT min(number) FROM system.numbers WHERE toUInt64(number % 1000) IN (SELECT DISTINCT blockSize() FROM system.numbers SETTINGS max_block_size = 123, max_rows_to_read = 1000, read_overflow_mode = 'break') SETTINGS max_rows_to_read = 1000000, read_overflow_mode = 'break';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:37.349085 [ 2956 ] {659a76f7-32da-4d88-96f9-cd1a9ca53a47} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:37.600223 [ 4191 ] {b0e54ebe-3cf7-452f-b557-922dde0678d1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(50, 'UInt64')) AND (Quantity = _CAST(2, 'UInt64')). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43530) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv2(price=50,quantity=2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:37.603884 [ 4191 ] {b0e54ebe-3cf7-452f-b557-922dde0678d1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(50, 'UInt64')) AND (Quantity = _CAST(2, 'UInt64')). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:37.992241 [ 3998 ] {987b61e5-d302-4950-8c72-b62024484023} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:37.998720 [ 3998 ] {987b61e5-d302-4950-8c72-b62024484023} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43522) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data AS data_1 FROM S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') SETTINGS use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:38.008691 [ 3998 ] {987b61e5-d302-4950-8c72-b62024484023} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:38.023216 [ 6665 ] {875d7008-3a70-45e2-b5d9-cc88a6b6aeee} executeQuery: Code: 456. DB::Exception: Substitution `quantity` is not set. (UNKNOWN_QUERY_PARAMETER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43538) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv2(price=50)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000118f8c25 5. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:79: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000118f80f4 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 13. /build/src/Storages/StorageView.cpp:230: DB::StorageView::replaceQueryParametersIfParametrizedView(std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000124d6be2 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1485: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e7dde 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:12:38.037649 [ 6665 ] {875d7008-3a70-45e2-b5d9-cc88a6b6aeee} TCPHandler: Code: 456. DB::Exception: Substitution `quantity` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000118f8c25 5. /build/src/Interpreters/ReplaceQueryParameterVisitor.cpp:79: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000118f80f4 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000118f8af8 13. /build/src/Storages/StorageView.cpp:230: DB::StorageView::replaceQueryParametersIfParametrizedView(std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000124d6be2 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1485: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e7dde 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:12:38.644728 [ 3998 ] {a0adc0c9-7d5c-4deb-9152-97dae30581c8} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:38.647268 [ 3998 ] {a0adc0c9-7d5c-4deb-9152-97dae30581c8} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43540) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data AS data_2 FROM S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') SETTINGS use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:38.654930 [ 3998 ] {a0adc0c9-7d5c-4deb-9152-97dae30581c8} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:622: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000108d89d0 9. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d251a 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d09cd 11. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:38.776089 [ 3998 ] {d104a3cb-3fa5-424a-8266-ef94c79404e8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(10, 'UInt64')) AND (Quantity = 3). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43592) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv3(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:38.793007 [ 3998 ] {d104a3cb-3fa5-424a-8266-ef94c79404e8} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(10, 'UInt64')) AND (Quantity = 3). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:38.960980 [ 6665 ] {f8f0ba2d-3956-46c0-a022-0b0b083fd732} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43698) (comment: 02124_buffer_insert_select_race.sh) (in query: SELECT * FROM t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:38.962217 [ 6665 ] {f8f0ba2d-3956-46c0-a022-0b0b083fd732} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:39.696596 [ 6665 ] {e3e63b0f-7347-4019-a55f-9e538f6cf329} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(10, 'UInt64')) OR (Price = (_CAST(10, 'UInt64') * 2)). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43750) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv4(price=10) ORDER BY Price), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:39.705440 [ 6665 ] {e3e63b0f-7347-4019-a55f-9e538f6cf329} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog WHERE (Price = _CAST(10, 'UInt64')) OR (Price = (_CAST(10, 'UInt64') * 2)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:39.807855 [ 8125 ] {e347bb6f-90fa-4c8f-8dc2-bb5961338be8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43746) (comment: 00041_aggregating_materialized_view.sql) (in query: INSERT INTO test.visits_null SELECT CounterID, StartDate, Sign, UserID FROM test.visits;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:39.821211 [ 8125 ] {e347bb6f-90fa-4c8f-8dc2-bb5961338be8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:12:39.997603 [ 5174 ] {bf37f214-42fa-45ea-9454-6685a31d1691} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_5_bad', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:40.017616 [ 5174 ] {bf37f214-42fa-45ea-9454-6685a31d1691} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43712) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_5_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]', 'foo'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:40.040827 [ 5174 ] {bf37f214-42fa-45ea-9454-6685a31d1691} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x0000000010946f1c 5. /build/src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000010943884 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000010942fc6 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010956046 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001094796d 9. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000010955f2d 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 13. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 15. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:12:40.355596 [ 5174 ] {084f0ff9-4c78-438f-b12e-eb31e32e3ea2} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo'): Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095648b 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 6. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:40.359561 [ 5174 ] {084f0ff9-4c78-438f-b12e-eb31e32e3ea2} executeQuery: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43774) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_f8hhnerk/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095648b 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 6. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:40.380471 [ 5174 ] {084f0ff9-4c78-438f-b12e-eb31e32e3ea2} TCPHandler: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095648b 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 6. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:41.408438 [ 8125 ] {34a85ac7-d8ff-4763-a063-035e5853b899} BackupsWorker: Failed to make backup Disk('backups', 'test_f8hhnerk/backup_2'): Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_f8hhnerk/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000108cea60 5. /build/src/Backups/BackupFactory.h:29: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x0000000010947667 6. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095f3b4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 10. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 12. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:41.453887 [ 8125 ] {34a85ac7-d8ff-4763-a063-035e5853b899} executeQuery: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_f8hhnerk/backup_2'). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43810) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO Disk('backups', 'test_f8hhnerk/backup_2') SETTINGS use_same_s3_credentials_for_base_backup=1, base_backup=Disk('backups', 'test_f8hhnerk/backup_1')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000108cea60 5. /build/src/Backups/BackupFactory.h:29: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x0000000010947667 6. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095f3b4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 10. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 12. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:41.488859 [ 8125 ] {34a85ac7-d8ff-4763-a063-035e5853b899} TCPHandler: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_f8hhnerk/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000108cea60 5. /build/src/Backups/BackupFactory.h:29: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x0000000010947667 6. /build/src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x00000000109438ae 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x0000000010944040 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001095f3b4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: 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) @ 0x00000000108d47ef 10. /build/src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000108d1284 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000108d0a37 12. /build/src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x000000001197ee0c 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:42.093222 [ 4006 ] {0f1e09d2-7617-4b97-b6b6-80d585e65223} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43622) (comment: 02124_buffer_insert_select_race.sh) (in query: INSERT INTO t_buffer_string SELECT number::String from numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d5e981 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb5a9f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:12:42.095560 [ 4006 ] {0f1e09d2-7617-4b97-b6b6-80d585e65223} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d5e981 8. /build/src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x0000000012cb5a9f 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:12:43.248720 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:44.251500 [ 8172 ] {2ae994ef-b325-4f1b-a215-e34ef2f14a84} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53456) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_Catalog VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:44.557338 [ 8172 ] {2ae994ef-b325-4f1b-a215-e34ef2f14a84} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:45.074983 [ 6836 ] {ada49892-a783-4f5b-9708-37bbc3be3d02} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53474) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO test_02428_Catalog VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:45.097302 [ 6836 ] {ada49892-a783-4f5b-9708-37bbc3be3d02} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:45.329210 [ 4006 ] {d72eb7cb-b577-47fb-bdb7-99e94fef4c0d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51136) (comment: 02875_merge_engine_set_index.sh) (in query: DROP DATABASE IF EXISTS test_w2x3dsj5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:45.345345 [ 4006 ] {d72eb7cb-b577-47fb-bdb7-99e94fef4c0d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:46.095806 [ 5056 ] {8847c130-7c7c-4769-849a-896ff2b9cd2d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(30, 'UInt64') HAVING Quantity IN (SELECT _CAST(8, 'UInt64')) LIMIT _CAST(1, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53520) (comment: 02428_parameterized_view.sh) (in query: SELECT Price FROM test_02428_pv5(price=30, quantity=8, limit=1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:46.109140 [ 5056 ] {8847c130-7c7c-4769-849a-896ff2b9cd2d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(30, 'UInt64') HAVING Quantity IN (SELECT _CAST(8, 'UInt64')) LIMIT _CAST(1, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:47.076677 [ 4027 ] {fa21ba3a-8903-4c90-8aae-31bc11c84f6b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43658) (comment: 02124_buffer_insert_select_race.sh) (in query: SELECT * FROM t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:47.077724 [ 4027 ] {fa21ba3a-8903-4c90-8aae-31bc11c84f6b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:47.310670 [ 4006 ] {4a3d6996-397c-4835-bf5f-f48dd9d7b9b5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53514) (comment: 03217_fliter_pushdown_no_keys.sql) (in query: select * from ( select sum(last_seen) as dates_seen, 1 as last_seen UNION ALL select sum(last_seen) as dates_seen, 3 as last_seen ) where last_seen > 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:47.323343 [ 4006 ] {4a3d6996-397c-4835-bf5f-f48dd9d7b9b5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:47.323731 [ 6665 ] {1bb620b1-baf7-4e5a-a7ed-32ee3eaad07b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51154) (comment: 02901_parallel_replicas_rollup.sh) (in query: DROP DATABASE IF EXISTS test_x2jp27cj ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:47.329952 [ 6665 ] {1bb620b1-baf7-4e5a-a7ed-32ee3eaad07b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:47.386500 [ 5174 ] {734f2a13-015e-4533-b6f1-f01d5bba0a5f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price + _CAST(10, 'UInt64') FROM test_11.test_02428_Catalog GROUP BY Price + _CAST(10, 'UInt64') ORDER BY Price + _CAST(10, 'UInt64') ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53578) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv6(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:47.427830 [ 5056 ] {518a1996-fd3f-4660-ad45-41757580befa} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51162) (comment: 02901_parallel_replicas_rollup.sh) (in query: DROP DATABASE IF EXISTS test_x2jp27cj ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:47.638119 [ 5174 ] {734f2a13-015e-4533-b6f1-f01d5bba0a5f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price + _CAST(10, 'UInt64') FROM test_11.test_02428_Catalog GROUP BY Price + _CAST(10, 'UInt64') ORDER BY Price + _CAST(10, 'UInt64') ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:47.639279 [ 5056 ] {518a1996-fd3f-4660-ad45-41757580befa} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:47.789726 [ 4027 ] {b7cc8166-b687-40ee-8d08-2ca6d4b90de5} executeQuery: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53608) (comment: 01732_union_and_union_all.sql) (in query: select 1 UNION select 1 UNION ALL select 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x00000000116f8599 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x00000000116f7857 6. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000010dd4095 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190dd7d 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:47.797217 [ 4027 ] {b7cc8166-b687-40ee-8d08-2ca6d4b90de5} TCPHandler: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x00000000116f8599 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x00000000116f7857 6. /build/src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000010dd4095 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190dd7d 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:12:47.855798 [ 5174 ] {8394f0b7-183b-4005-b154-030c0cb0e669} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51190) (comment: 02901_parallel_replicas_rollup.sh) (in query: DROP DATABASE IF EXISTS test_x2jp27cj ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:47.862465 [ 5174 ] {8394f0b7-183b-4005-b154-030c0cb0e669} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:48.005949 [ 5056 ] {56602e0f-6090-4c47-8985-2f862819f761} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51194) (comment: 03240_insert_select_named_tuple.sql) (in query: DROP DATABASE IF EXISTS test_hiv7c3b6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:48.007558 [ 5056 ] {56602e0f-6090-4c47-8985-2f862819f761} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:48.141956 [ 4027 ] {0f9e836a-98d6-44f3-bb35-eca583a73f46} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51204) (comment: 03240_insert_select_named_tuple.sql) (in query: DROP DATABASE IF EXISTS test_hiv7c3b6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:48.145266 [ 4027 ] {0f9e836a-98d6-44f3-bb35-eca583a73f46} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:48.145807 [ 4197 ] {a6384aec-d7be-43a2-bbe5-19c62ee6776c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=730). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43684) (comment: 02124_buffer_insert_select_race.sh) (in query: SELECT * FROM t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:48.150242 [ 4197 ] {a6384aec-d7be-43a2-bbe5-19c62ee6776c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=730). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:48.203789 [ 6155 ] {b8876b24-2b65-49f7-8460-123fd26cab70} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51220) (comment: 03240_insert_select_named_tuple.sql) (in query: DROP DATABASE IF EXISTS test_hiv7c3b6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:48.204871 [ 6155 ] {b8876b24-2b65-49f7-8460-123fd26cab70} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:48.225974 [ 5056 ] {733c8e8b-c23f-42a6-8236-439a728c7156} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53622) (comment: 01016_uniqCombined64.sql) (in query: -- for small cardinality the 64 bit hash perform worse, but for 1e10: -- 4 byte hash: 2.8832809652e10 -- 8 byte hash: 0.9998568925e10 -- but hence checking with 1e10 values takes too much time (~45 secs), this -- test is just to ensure that the result is different (and to document the -- outcome). SELECT uniqCombined(number) FROM numbers(1e7);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:48.241192 [ 5056 ] {733c8e8b-c23f-42a6-8236-439a728c7156} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:48.314156 [ 6985 ] {f05ab427-7185-474e-8534-a84cd4858177} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51226) (comment: 03240_insert_select_named_tuple.sql) (in query: DROP DATABASE IF EXISTS test_hiv7c3b6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:48.318244 [ 6985 ] {f05ab427-7185-474e-8534-a84cd4858177} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:48.451408 [ 8125 ] {5e3c5d79-70f2-4886-ac5d-fbeb57d74645} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column StartURL): (while reading from part /var/lib/clickhouse/store/9f2/9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672/201403_1_1_0/ in table test.visits (9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672) located on disk default of type local, from mark 0 with max_rows_to_read = 18681): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53580) (comment: 00181_cross_join_compression.sql) (in query: SELECT CounterID, StartURL FROM unit, test.visits ORDER BY (CounterID, StartURL) DESC LIMIT 1000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 14. /build/src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba437c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 16. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 17. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<4>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d64f52 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 20. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:12:48.482962 [ 8125 ] {5e3c5d79-70f2-4886-ac5d-fbeb57d74645} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column StartURL): (while reading from part /var/lib/clickhouse/store/9f2/9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672/201403_1_1_0/ in table test.visits (9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672) located on disk default of type local, from mark 0 with max_rows_to_read = 18681): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 14. /build/src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba437c 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 16. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 17. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<4>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d64f52 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 20. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:12:48.538813 [ 4197 ] {c2e4341d-4021-4706-8074-c4186b32ee30} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53630) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:48.542286 [ 4191 ] {2357d2a3-4588-4047-997f-2a3cae67e04a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43632) (comment: 02124_buffer_insert_select_race.sh) (in query: SELECT * FROM t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:48.544112 [ 4191 ] {2357d2a3-4588-4047-997f-2a3cae67e04a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:48.558123 [ 4197 ] {c2e4341d-4021-4706-8074-c4186b32ee30} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:48.824359 [ 5056 ] {0a884b24-bf23-42f7-b1db-7cf92ba28e13} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price / _CAST(10, 'UInt64') FROM test_11.test_02428_Catalog ORDER BY Price ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53652) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv7(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:48.839585 [ 5056 ] {0a884b24-bf23-42f7-b1db-7cf92ba28e13} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price / _CAST(10, 'UInt64') FROM test_11.test_02428_Catalog ORDER BY Price ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:49.228107 [ 4197 ] {6d3eabe9-026c-4334-8aae-9554701b6a35} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53678) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:49.231302 [ 4197 ] {6d3eabe9-026c-4334-8aae-9554701b6a35} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:49.582920 [ 6836 ] {d3f5600b-8def-42fc-9c70-07b79fdf5c24} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02124_buffer_insert_select_race.sh) (in query: /* ddl_entry=query-0000000003 */ TRUNCATE TABLE test_wpgmkpi1.t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:49.614307 [ 6836 ] {d3f5600b-8def-42fc-9c70-07b79fdf5c24} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53722) (comment: 02124_buffer_insert_select_race.sh) (in query: DROP TABLE t_buffer_string), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:49.635186 [ 6836 ] {d3f5600b-8def-42fc-9c70-07b79fdf5c24} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:49.875453 [ 4191 ] {4bfbfad0-1ff8-4b1c-ac0c-5483781e87fa} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price IN _CAST([10, 20], 'Array(UInt64)') ORDER BY Price ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53748) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv8(prices=[10,20])), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:49.900120 [ 4191 ] {4bfbfad0-1ff8-4b1c-ac0c-5483781e87fa} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price IN _CAST([10, 20], 'Array(UInt64)') ORDER BY Price ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:50.310525 [ 4006 ] {9a744af5-8e7a-4eb8-b544-1c18fcf800c6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53632) (comment: 00693_max_block_size_system_tables_columns.sql) (in query: SELECT (SELECT count() FROM system.tables SETTINGS max_block_size = 100) = (SELECT count() FROM system.tables SETTINGS max_block_size = 1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:50.312733 [ 4006 ] {9a744af5-8e7a-4eb8-b544-1c18fcf800c6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:50.458090 [ 4191 ] {1ffdacf8-823d-4bdc-89af-2ef8c2369718} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53752) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:50.460796 [ 4191 ] {1ffdacf8-823d-4bdc-89af-2ef8c2369718} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:50.709625 [ 5056 ] {df0bbba5-a4bc-441f-86be-3eece7ddb2ca} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE (Price IN (10, 20)) AND (Quantity = _CAST(3, 'UInt64')) ORDER BY Price ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53814) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv9(quantity=3)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:50.741322 [ 5056 ] {df0bbba5-a4bc-441f-86be-3eece7ddb2ca} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE (Price IN (10, 20)) AND (Quantity = _CAST(3, 'UInt64')) ORDER BY Price ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:51.659057 [ 2956 ] {d6a387de-62cc-4c29-8611-1601fc3ea236} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64') ORDER BY Price ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53856) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv10(Pri=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:51.669137 [ 2956 ] {d6a387de-62cc-4c29-8611-1601fc3ea236} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64') ORDER BY Price ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:51.710694 [ 6986 ] {bb276117-9ea5-4db1-b8ae-32d44972a009} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53842) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a IN (0, 1) AND b IN (0, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:51.729843 [ 6986 ] {bb276117-9ea5-4db1-b8ae-32d44972a009} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:53.045657 [ 5056 ] {b7145169-9f0e-448e-a1fe-9af36caa660b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53922) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv11(price=10)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:53.052004 [ 5056 ] {b7145169-9f0e-448e-a1fe-9af36caa660b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price = _CAST(10, 'UInt64'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:53.149652 [ 4006 ] {9686d8f6-b2fa-4d78-83e7-2fe87b17161d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53912) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0 AND c = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:53.194325 [ 4006 ] {9686d8f6-b2fa-4d78-83e7-2fe87b17161d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:12:53.564227 [ 6398 ] {11409b4c-1d5e-4844-9671-698031a82616} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51322) (comment: 02766_bitshift_with_const_arguments.sql) (in query: DROP DATABASE IF EXISTS test_xxgsgpzc ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:53.578177 [ 6398 ] {11409b4c-1d5e-4844-9671-698031a82616} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:54.025674 [ 6986 ] {b3a4fd14-a19f-4a4d-b198-e1df38950cb2} executeQuery: Code: 57. DB::Exception: Table test_icdm71q2.t_missed_subcolumns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03203_fill_missed_subcolumns.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_icdm71q2.t_missed_subcolumns UUID '14e37d3c-bde2-4b58-909f-88e68a35547b' (`id` UInt64, `n.a` Array(Nullable(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 7545, min_bytes_for_wide_part = 637914471, 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 = 0, compact_parts_max_bytes_to_buffer = 291290942, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18701861, merge_max_block_size = 20871, old_parts_lifetime = 178., 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 = 17641122, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 86991, primary_key_compress_block_size = 29916), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:54.050441 [ 6986 ] {b3a4fd14-a19f-4a4d-b198-e1df38950cb2} executeQuery: Code: 57. DB::Exception: Table test_icdm71q2.t_missed_subcolumns already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53886) (comment: 03203_fill_missed_subcolumns.sql) (in query: CREATE TABLE t_missed_subcolumns (`id` UInt64, `n.a` Array(Nullable(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 7545, min_bytes_for_wide_part = 637914471, 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 = 0, compact_parts_max_bytes_to_buffer = 291290942, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18701861, merge_max_block_size = 20871, old_parts_lifetime = 178., 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 = 17641122, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 86991, primary_key_compress_block_size = 29916), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:54.069167 [ 6986 ] {b3a4fd14-a19f-4a4d-b198-e1df38950cb2} TCPHandler: Code: 57. DB::Exception: Table test_icdm71q2.t_missed_subcolumns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:54.195457 [ 6986 ] {a09068dd-b1f8-4fe1-b8b0-5bf6aaef76b1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price IN (SELECT number FROM numbers(_CAST(11, 'UInt64'))). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53960) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_pv12(price=11)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:54.198038 [ 6986 ] {a09068dd-b1f8-4fe1-b8b0-5bf6aaef76b1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT Price FROM test_11.test_02428_Catalog WHERE Price IN (SELECT number FROM numbers(_CAST(11, 'UInt64'))). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:54.524230 [ 6986 ] {e15b7a75-35e5-4386-8946-2d365b2b4df1} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:12:54.530903 [ 6986 ] {e15b7a75-35e5-4386-8946-2d365b2b4df1} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33924) (comment: 02428_parameterized_view.sh) (in query: CREATE TABLE `02428_otel_traces` (`TraceId` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02428_parameterized_view_test_11/otel_traces', 'r1') ORDER BY TraceId SETTINGS index_granularity = 43449, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8693392276763916, 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 = 126527738, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 20558095, merge_max_block_size = 3585, old_parts_lifetime = 109., prefer_fetch_merged_part_size_threshold = 2093655777, 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 = 14112612, concurrent_part_removal_threshold = 38, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 85484, primary_key_compress_block_size = 12175), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:54.576021 [ 6986 ] {e15b7a75-35e5-4386-8946-2d365b2b4df1} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:54.649496 [ 2956 ] {7114de99-0203-4948-930b-d9ba85827ee9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33936) (comment: 02177_sum_if_not_found.sql) (in query: SELECT sumIf(1, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:54.653583 [ 2956 ] {7114de99-0203-4948-930b-d9ba85827ee9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:54.929630 [ 6155 ] {80b5989c-d4d6-4a7d-8a23-90bbfdcbb9b4} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:12:54.934334 [ 6155 ] {80b5989c-d4d6-4a7d-8a23-90bbfdcbb9b4} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33966) (comment: 02428_parameterized_view.sh) (in query: CREATE TABLE `02428_otel_traces_trace_id_ts` (`TraceId` String, `Start` Timestamp) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02428_parameterized_view_test_11/otel_traces_trace_id_ts', 'r1') ORDER BY TraceId SETTINGS index_granularity = 43449, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8693392276763916, 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 = 126527738, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 20558095, merge_max_block_size = 3585, old_parts_lifetime = 109., prefer_fetch_merged_part_size_threshold = 2093655777, 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 = 14112612, concurrent_part_removal_threshold = 38, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 85484, primary_key_compress_block_size = 12175), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:54.936469 [ 6986 ] {e5cfe342-809a-4095-9985-0b9b8a22a56f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33944) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE (a = 0 OR a = 1) AND (b = 0 OR b = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:54.953096 [ 6155 ] {80b5989c-d4d6-4a7d-8a23-90bbfdcbb9b4} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:54.965678 [ 6986 ] {e5cfe342-809a-4095-9985-0b9b8a22a56f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:12:55.344942 [ 8172 ] {48da7817-b0e0-4c67-9338-15d47cb0637b} executeQuery: Code: 60. DB::Exception: Table test_11.`02428_otel_traces` does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34010) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO 02428_otel_traces(TraceId) VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x00000000115f5c80 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d0c 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:55.369045 [ 8172 ] {48da7817-b0e0-4c67-9338-15d47cb0637b} TCPHandler: Code: 60. DB::Exception: Table test_11.`02428_otel_traces` does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x00000000115f5c80 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d0c 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:55.522939 [ 6986 ] {0fc5e928-d9d0-44ea-89f4-e49971ea73d5} DatabaseReplicated (test_smhmpjyy): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:12:55.541196 [ 6986 ] {0fc5e928-d9d0-44ea-89f4-e49971ea73d5} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33988) (comment: 00926_zookeeper_adaptive_index_granularity_replicated_merge_tree_long.sql) (in query: CREATE TABLE zero_rows_per_granule1 ( p Date, k UInt64, v1 UInt64, v2 Int64 ) ENGINE ReplicatedMergeTree('/clickhouse/tables/{database}/test_00926/zero_rows_in_granule', '1') PARTITION BY toYYYYMM(p) ORDER BY k SETTINGS index_granularity_bytes = 20, min_index_granularity_bytes = 10, write_final_mark = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:55.554922 [ 6986 ] {0fc5e928-d9d0-44ea-89f4-e49971ea73d5} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:55.697726 [ 6986 ] {b3bf4036-ec8d-46d9-bd5d-0b758aafa997} executeQuery: Code: 60. DB::Exception: Table test_11.`02428_otel_traces_trace_id_ts` does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34028) (comment: 02428_parameterized_view.sh) (in query: INSERT INTO 02428_otel_traces_trace_id_ts(TraceId, Start) VALUES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x00000000115f5c80 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d0c 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:55.699293 [ 6986 ] {b3bf4036-ec8d-46d9-bd5d-0b758aafa997} TCPHandler: Code: 60. DB::Exception: Table test_11.`02428_otel_traces_trace_id_ts` does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x00000000115f5c80 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910d0c 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:12:55.753954 [ 6155 ] {c3e275c6-3176-474a-ad5d-17c3914c0677} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34004) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b <= 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:55.761025 [ 6155 ] {c3e275c6-3176-474a-ad5d-17c3914c0677} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:56.322025 [ 5054 ] {d763899c-b396-4080-8831-f162a6ad92dd} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34058) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND c = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:56.337014 [ 5054 ] {d763899c-b396-4080-8831-f162a6ad92dd} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:56.541590 [ 6398 ] {e5e7c6db-37e0-4fe4-b508-f7392149d078} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.02428_otel_traces' in scope WITH '1' AS trace_id, (SELECT min(Start) FROM test_11.`02428_otel_traces_trace_id_ts` WHERE TraceId = trace_id) AS start SELECT TraceId AS traceID FROM test_11.`02428_otel_traces`. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34098) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM 02428_trace_view(trace_id='1')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:56.546041 [ 6398 ] {e5e7c6db-37e0-4fe4-b508-f7392149d078} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.02428_otel_traces' in scope WITH '1' AS trace_id, (SELECT min(Start) FROM test_11.`02428_otel_traces_trace_id_ts` WHERE TraceId = trace_id) AS start SELECT TraceId AS traceID FROM test_11.`02428_otel_traces`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000110e8220 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103cc22 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:12:56.559458 [ 6836 ] {a77ca1d8-3cc0-4548-99b9-5ffa205887d8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51420) (comment: 00962_enumNotExect.sql) (in query: DROP DATABASE IF EXISTS test_dptu3ob5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:12:56.560387 [ 6836 ] {a77ca1d8-3cc0-4548-99b9-5ffa205887d8} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:56.562241 [ 6986 ] {42fbe9ff-6f00-4bed-8b5c-45f7569b8f78} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34092) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a45f6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4048 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4352 12. /build/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*) @ 0x000000001190d9b7 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:56.573146 [ 6986 ] {42fbe9ff-6f00-4bed-8b5c-45f7569b8f78} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000116a45f6 10. /build/src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4048 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000116a4352 12. /build/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*) @ 0x000000001190d9b7 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:12:56.773007 [ 6155 ] {479004b7-c93e-4e20-8cba-630ff415935b} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34106) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 OR a = 1 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:56.814786 [ 6155 ] {479004b7-c93e-4e20-8cba-630ff415935b} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:56.922854 [ 6986 ] {6f833aee-6934-463b-8dfd-6172b43635b6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34122) (comment: 02428_parameterized_view.sh) (in query: CREATE MATERIALIZED VIEW test_02428_mv1 ENGINE = ReplicatedMergeTree('/clickhouse/tables/02428_parameterized_view_test_11/materialized_view', 'r1') ORDER BY Name AS SELECT * FROM test_02428_Catalog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155193c 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:56.925948 [ 6986 ] {6f833aee-6934-463b-8dfd-6172b43635b6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_11.test_02428_Catalog' in scope SELECT * FROM test_11.test_02428_Catalog. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001164829b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155193c 13. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:12:57.261654 [ 8172 ] {c922a407-3d79-42ea-b4b7-2d231f4684a9} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_mv1. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34160) (comment: 02428_parameterized_view.sh) (in query: SELECT * FROM test_02428_mv1(test)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:57.282599 [ 8172 ] {c922a407-3d79-42ea-b4b7-2d231f4684a9} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_mv1. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4585: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103dde1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:12:57.564473 [ 6986 ] {fa0661bb-6684-481a-960c-52cf9b96e3b1} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34148) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0 OR a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:57.569307 [ 6986 ] {fa0661bb-6684-481a-960c-52cf9b96e3b1} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:57.635944 [ 6665 ] {86abf1b4-7dc2-4e80-adc8-a0357b33a1ca} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_mv1 does not exist. Maybe you meant test_11.test_02428_pv1?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34174) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_mv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:57.648751 [ 6665 ] {86abf1b4-7dc2-4e80-adc8-a0357b33a1ca} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_mv1 does not exist. Maybe you meant test_11.test_02428_pv1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:57.930055 [ 6986 ] {27945b5e-46d4-48bf-8136-2277315fe338} DatabaseReplicated (test_6ru7fgf8): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:12:57.932443 [ 6986 ] {27945b5e-46d4-48bf-8136-2277315fe338} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34180) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: CREATE TABLE mutations_r1 (`x` UInt32, `y` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00652_replicated_mutations_default_database_zookeeper_test_6ru7fgf8/mutations', 'r1') ORDER BY x SETTINGS index_granularity = 37980, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 205876510, compact_parts_max_bytes_to_buffer = 249124845, compact_parts_max_granules_to_buffer = 40, compact_parts_merge_max_bytes_to_prefetch_part = 21362720, merge_max_block_size = 8133, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 967577, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5594228736, index_granularity_bytes = 8910005, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 15701, primary_key_compress_block_size = 77173), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:57.937223 [ 6986 ] {27945b5e-46d4-48bf-8136-2277315fe338} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:58.048513 [ 5174 ] {b7d190fe-d4ff-46f9-8658-24d1df034ad0} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000024 */ TRUNCATE VIEW test_11.test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.078678 [ 5174 ] {b7d190fe-d4ff-46f9-8658-24d1df034ad0} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34198) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.087347 [ 5174 ] {b7d190fe-d4ff-46f9-8658-24d1df034ad0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.175524 [ 8172 ] {93f8ef3f-5fd0-443d-86d7-56a5e7bd555e} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34188) (comment: 00754_distributed_optimize_skip_select_on_unused_shards.sh) (in query: SELECT count(*) FROM distributed WHERE a = 0 AND b = 0 OR c = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:58.188273 [ 8172 ] {93f8ef3f-5fd0-443d-86d7-56a5e7bd555e} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x00000000124f3d03 3. /build/src/Client/HedgedConnectionsFactory.cpp:0: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x0000000012beafe2 4. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012be2f55 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c0d50d 6. /build/src/QueryPipeline/RemoteQueryExecutor.cpp:217: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x0000000010c07619 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x0000000010c00605 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1fd43 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:12:58.315509 [ 6665 ] {2ddb6793-b2c8-4d16-ab30-52dd38512537} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_r1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34204) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: SELECT * FROM mutations_r1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:58.320276 [ 6665 ] {2ddb6793-b2c8-4d16-ab30-52dd38512537} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_r1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:12:58.467099 [ 5174 ] {674ed811-4c01-4320-a2c2-9399632852d1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000025 */ TRUNCATE VIEW test_11.test_02428_pv2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.483077 [ 5174 ] {674ed811-4c01-4320-a2c2-9399632852d1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34222) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.489106 [ 5174 ] {674ed811-4c01-4320-a2c2-9399632852d1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:58.584057 [ 5174 ] {baf78b62-ec41-45e4-a6e7-cb0e78bf61f9} executeQuery: Code: 60. DB::Exception: Table test_6ru7fgf8.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34238) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE mutations_r1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:58.589832 [ 5174 ] {baf78b62-ec41-45e4-a6e7-cb0e78bf61f9} TCPHandler: Code: 60. DB::Exception: Table test_6ru7fgf8.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:58.888208 [ 6379 ] {9e0052b8-c40c-4313-a6e9-b9c5e4d9d024} executeQuery: Code: 60. DB::Exception: Table test_6ru7fgf8.for_subquery does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34272) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE for_subquery), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:58.898195 [ 6379 ] {9e0052b8-c40c-4313-a6e9-b9c5e4d9d024} TCPHandler: Code: 60. DB::Exception: Table test_6ru7fgf8.for_subquery does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:12:59.236293 [ 8172 ] {970f03e7-9623-469d-bbd9-b56ccfdf8f37} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: -- { echo } SELECT lcm(9223372036854775807, -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000099913e9 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d418a 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.239408 [ 8172 ] {970f03e7-9623-469d-bbd9-b56ccfdf8f37} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000099913e9 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d418a 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.266168 [ 8172 ] {40bc219a-650f-4a88-ab2e-c4bb04fa2b14} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(9223372036854775808, -9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000099913e9 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d418a 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.270743 [ 8172 ] {40bc219a-650f-4a88-ab2e-c4bb04fa2b14} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(unsigned long, long) @ 0x00000000099913e9 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d418a 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.355445 [ 6379 ] {eb64d052-943c-4ee6-b499-dc57e9c90150} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34314) (comment: 02877_optimize_read_in_order_from_view.sh) (in query: DROP TABLE view1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:59.366797 [ 8172 ] {dc8d4bd1-d3ea-4bac-b08d-7aabc838bcf4} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-9223372036854775808, 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x00000000099a8f89 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099f36ca 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b98c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.381255 [ 6379 ] {eb64d052-943c-4ee6-b499-dc57e9c90150} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:12:59.389462 [ 8172 ] {dc8d4bd1-d3ea-4bac-b08d-7aabc838bcf4} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x00000000099a8f89 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099f36ca 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b98c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.484447 [ 8172 ] {7d4ac84f-9d8b-440c-823d-ecb00e2fe01c} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-9223372036854775807, 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x00000000099a8f89 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099f36ca 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b98c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.486814 [ 8172 ] {7d4ac84f-9d8b-440c-823d-ecb00e2fe01c} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(long, unsigned long) @ 0x00000000099a8f89 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099f36ca 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b98c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.541528 [ 3418 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:12:59.612256 [ 8172 ] {975dd706-f1a4-437c-bd77-6acda84a7ca5} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x00000000099906fc 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d3149 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.625926 [ 8172 ] {975dd706-f1a4-437c-bd77-6acda84a7ca5} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT lcm(9223372036854775808, -1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x0000000008bb8cab 4. /build/src/Functions/GCDLCMImpl.h:0: long DB::GCDLCMImpl, DB::(anonymous namespace)::LCMImpl::NameLCM>::apply(unsigned long, DB::(anonymous namespace)) @ 0x00000000099906fc 5. /build/src/Functions/FunctionBinaryArithmetic.h:2136: _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_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x00000000099d3149 6. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000099b95c6 7. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b7ee1 8. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000099b71aa 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:12:59.837058 [ 8172 ] {7b3a682b-1d36-4a44-847b-7c8b493ca367} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34274) (comment: 01666_lcm_ubsan.sql) (in query: SELECT lcm(-170141183460469231731687303715884105728, -170141183460469231731687303715884105728);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009a09545 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:12:59.839731 [ 8172 ] {7b3a682b-1d36-4a44-847b-7c8b493ca367} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000009a09545 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:12:59.954170 [ 4027 ] {66ddda7c-27c2-4eb9-b0bb-3175a409e6e9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000028 */ TRUNCATE VIEW test_11.test_02428_pv6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:59.969835 [ 4027 ] {66ddda7c-27c2-4eb9-b0bb-3175a409e6e9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34352) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:12:59.972718 [ 4027 ] {66ddda7c-27c2-4eb9-b0bb-3175a409e6e9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.042197 [ 3627 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1f9b7224-725a-4304-bbc5-0deeb6da8271::202506_1_21_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:00.350648 [ 2952 ] {138a28bb-0a6e-4793-9d0d-a4ff535b4277} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000029 */ TRUNCATE VIEW test_11.test_02428_pv7), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.449041 [ 2952 ] {138a28bb-0a6e-4793-9d0d-a4ff535b4277} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34390) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv7), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.457130 [ 2952 ] {138a28bb-0a6e-4793-9d0d-a4ff535b4277} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.626560 [ 2952 ] {87cde66b-5ba4-485c-8bb8-6d0ffc56c607} executeQuery: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x00'::AggregateFunction(groupBitmap, UInt32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x000000000ff66ada 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 7. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 9. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 10. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:00.627848 [ 2952 ] {87cde66b-5ba4-485c-8bb8-6d0ffc56c607} TCPHandler: Code: 117. DB::Exception: Incorrect size (0) in groupBitmap.: In scope SELECT CAST('\0', 'AggregateFunction(groupBitmap, UInt32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmapData.h:0: _ZN2DB25RoaringBitmapWithSmallSetIjLDu32EE4readERNS_10ReadBufferE @ 0x000000000ff66ada 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 7. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 9. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 10. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:00.633028 [ 5174 ] {ffbe7615-b239-4187-b29b-f14494fbcb84} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34284) (comment: 02559_multiple_read_steps_in_prewhere.sql) (in query: SELECT cast(id1 as UInt16) AS cond1 FROM test_02559 PREWHERE cond1 LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x000000001218eab3 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee93f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128eca8c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea743 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:00.635529 [ 5174 ] {ffbe7615-b239-4187-b29b-f14494fbcb84} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 of column for filter. Must be UInt8 or Nullable(UInt8) or Const variants of them.: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Columns/FilterDescription.cpp:0: DB::FilterDescription::FilterDescription(DB::IColumn const&) @ 0x000000001218eab3 5. /build/contrib/boost/boost/smart_ptr/detail/operator_bool.hpp:14: DB::FilterWithCachedCount::FilterWithCachedCount(COW::immutable_ptr const&) @ 0x00000000128ee93f 6. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::executePrewhereActionsAndFilterColumns(DB::MergeTreeRangeReader::ReadResult&) const @ 0x00000000128eca8c 7. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:1081: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128ea743 8. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 9. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 10. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 11. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:00.710053 [ 2956 ] {43679a33-f3ed-4e98-af73-11e70e179118} 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.10505.altinitytest (altinity build)) (from [::1]:34392) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x0000000012e78f7a 5. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x0000000012e78975 6. /build/contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000012e81c16 7. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000012e7b70d 8. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e79387 9. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 17. /build/src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000001225e860 18. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 19. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 21. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:00.710304 [ 2952 ] {462c528c-a848-485a-aa75-2aeb8afce729} executeQuery: std::exception. Code: 1001, type: std::runtime_error, e.what() = ran out of bytes (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x01\x01\x01'::AggregateFunction(groupBitmap, UInt64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x000000001851bc54 1. /build/contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x000000000ff679f1 2. /build/contrib/llvm-project/libcxx/include/new:246: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x000000000ff67425 3. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 5. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 7. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 8. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:13:00.712067 [ 2952 ] {462c528c-a848-485a-aa75-2aeb8afce729} TCPHandler: Code: 1001. DB::Exception: std::runtime_error: ran out of bytes. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(char const*) @ 0x000000001851bc54 1. /build/contrib/croaring/cpp/roaring64map.hh:1186: roaring::Roaring64Map::readSafe(char const*, unsigned long) @ 0x000000000ff679f1 2. /build/contrib/llvm-project/libcxx/include/new:246: _ZN2DB25RoaringBitmapWithSmallSetImLDu32EE4readERNS_10ReadBufferE @ 0x000000000ff67425 3. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 5. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 7. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 8. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:13:00.712777 [ 2956 ] {43679a33-f3ed-4e98-af73-11e70e179118} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:0: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x0000000012e78f7a 5. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x0000000012e78975 6. /build/contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x0000000012e81c16 7. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x0000000012e7b70d 8. /build/src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e79387 9. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 10. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 11. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 17. /build/src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000001225e860 18. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 19. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 21. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 25. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:00.861301 [ 6665 ] {6d2c5cea-cf73-415d-8ae0-7c2e27d47105} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000030 */ TRUNCATE VIEW test_11.test_02428_pv8), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.876062 [ 3832 ] {1713d3dd-d649-4725-ab82-127672248497} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string1').). 2025.06.25 16:13:00.878505 [ 6665 ] {6d2c5cea-cf73-415d-8ae0-7c2e27d47105} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34418) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv8), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.894500 [ 6665 ] {6d2c5cea-cf73-415d-8ae0-7c2e27d47105} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:00.896867 [ 2952 ] {58c66733-9664-4914-8991-04db437d1a92} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT '\x02\x00\x0d'::AggregateFunction(topK, UInt256);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000073d778b 4. /build/src/IO/ReadBuffer.h:0: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d76e7 5. /build/src/IO/VarInt.h:111: DB::SpaceSaving, HashCRC32>>::Counter::read(DB::ReadBuffer&) @ 0x000000000fec9edb 6. /build/src/Common/HashTable/HashTable.h:761: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x000000000fec9e0a 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 9. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 28. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 2025.06.25 16:13:00.906639 [ 2952 ] {58c66733-9664-4914-8991-04db437d1a92} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 2. Bytes expected: 32.: In scope SELECT CAST('\0\r', 'AggregateFunction(topK, UInt256)'). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000073d778b 4. /build/src/IO/ReadBuffer.h:0: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d76e7 5. /build/src/IO/VarInt.h:111: DB::SpaceSaving, HashCRC32>>::Counter::read(DB::ReadBuffer&) @ 0x000000000fec9edb 6. /build/src/Common/HashTable/HashTable.h:761: DB::SpaceSaving, HashCRC32>>::read(DB::ReadBuffer&) @ 0x000000000fec9e0a 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 9. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 28. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 2025.06.25 16:13:01.040659 [ 2952 ] {f7def2d3-a49e-4114-99f4-1ada2cdddd6b} executeQuery: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300')::AggregateFunction(minDistinct, Int8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000078742ab 4. /build/src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x000000000f07b3c2 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 7. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 9. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 10. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:01.043098 [ 2952 ] {f7def2d3-a49e-4114-99f4-1ada2cdddd6b} TCPHandler: Code: 128. DB::Exception: The size of serialized hash table is suspiciously large: 4502748553425166142: In scope SELECT CAST(unhex('bebebebebebebebebebebebebebebebebebebebebebebebebebebebebebebe0c0c3131313131313131313131313173290aee00b300'), 'AggregateFunction(minDistinct, Int8)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000078742ab 4. /build/src/Common/HashTable/HashTable.h:1334: HashTable<_BitInt(8), HashTableCell, HashTableNoState>, HashTableNoState, HashTableGrower<4ul>, AllocatorWithStackMemory, 16ul, 1ul>>::read(DB::ReadBuffer&) @ 0x000000000f07b3c2 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 7. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 9. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 10. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:01.295228 [ 2956 ] {704e99f3-772d-49ce-b146-b367bebf52c1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000031 */ TRUNCATE VIEW test_11.test_02428_pv9), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:01.337454 [ 2956 ] {704e99f3-772d-49ce-b146-b367bebf52c1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34444) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv9), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:01.346936 [ 2956 ] {704e99f3-772d-49ce-b146-b367bebf52c1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:01.422108 [ 2952 ] {ed045fcf-f503-4809-8d9b-a4272043f5a0} executeQuery: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000000f43300b 4. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000000f432dba 5. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000000f443718 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.423591 [ 2952 ] {ed045fcf-f503-4809-8d9b-a4272043f5a0} TCPHandler: Code: 117. DB::Exception: The number of elements 2816 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('01000b0b0b0d0d0d0d7175616e74696c6554696d696e672c20496e743332000300'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000000f43300b 4. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000000f432dba 5. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000000f443718 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.523985 [ 2952 ] {98f1a17c-aa62-468c-bf04-72dcb8570d11} executeQuery: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('010001')::AggregateFunction(quantileTiming, Int32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000000f43300b 4. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000000f432dba 5. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000000f443718 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.525892 [ 2952 ] {98f1a17c-aa62-468c-bf04-72dcb8570d11} TCPHandler: Code: 117. DB::Exception: The number of elements 256 for the 'tiny' kind of quantileTiming is exceeding the maximum of 31: In scope SELECT CAST(unhex('010001'), 'AggregateFunction(quantileTiming, Int32)'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned short&, int&&) @ 0x000000000f43300b 4. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::detail::QuantileTimingTiny::deserialize(DB::ReadBuffer&) @ 0x000000000f432dba 5. /build/src/AggregateFunctions/QuantileTiming.h:0: DB::QuantileTiming::deserialize(DB::ReadBuffer&) @ 0x000000000f443718 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.681123 [ 2952 ] {3ced177c-c78e-49b1-b6ca-c94e53f145c7} executeQuery: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34410) (comment: 02688_aggregate_states.sql) (in query: SELECT unhex('0a00797979797979797979790a0a6e')::AggregateFunction(minForEach, Ring);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000078742ab 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:0: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x00000000101ef6b3 5. /build/src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:263: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000101ee770 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.686025 [ 2952 ] {3ced177c-c78e-49b1-b6ca-c94e53f145c7} TCPHandler: Code: 128. DB::Exception: Suspiciously large array size (8753160913407246346) in -ForEach aggregate function: In scope SELECT CAST(unhex('0a00797979797979797979790a0a6e'), 'AggregateFunction(minForEach, Ring)'). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x00000000078742ab 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:0: DB::AggregateFunctionForEach::ensureAggregateData(char*, unsigned long, DB::Arena&) const @ 0x00000000101ef6b3 5. /build/src/AggregateFunctions/Combinators/AggregateFunctionForEach.h:263: DB::AggregateFunctionForEach::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000101ee770 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:0: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000010cdbe72 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010cdc0de 8. /build/src/IO/BufferBase.h:41: DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000007100350 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000072a1021 10. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 11. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 18. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 21. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 24. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 27. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 28. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:13:01.772347 [ 2956 ] {762f2884-20b1-4696-976a-c9813b35c618} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000032 */ TRUNCATE VIEW test_11.test_02428_pv10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:01.797809 [ 2956 ] {762f2884-20b1-4696-976a-c9813b35c618} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34480) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:01.810271 [ 2956 ] {762f2884-20b1-4696-976a-c9813b35c618} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.165989 [ 8125 ] {e5345c9d-61de-4b86-b3cc-b68d11803188} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000033 */ DROP VIEW test_11.test_02428_pv11 SYNC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.191159 [ 8125 ] {e5345c9d-61de-4b86-b3cc-b68d11803188} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34516) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv11), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.193352 [ 8125 ] {e5345c9d-61de-4b86-b3cc-b68d11803188} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.746998 [ 8125 ] {38bef168-bd38-4483-a07c-039ec3273491} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000034 */ TRUNCATE VIEW test_11.test_02428_pv12), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.763860 [ 8125 ] {38bef168-bd38-4483-a07c-039ec3273491} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34550) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_pv12), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:02.771909 [ 8125 ] {38bef168-bd38-4483-a07c-039ec3273491} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:03.279963 [ 4197 ] {dd7f6109-a527-4db5-85e9-f8196fb423d6} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_v1 does not exist. Maybe you meant test_11.test_02428_pv1?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34596) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW test_02428_v1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:03.286593 [ 4197 ] {dd7f6109-a527-4db5-85e9-f8196fb423d6} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_v1 does not exist. Maybe you meant test_11.test_02428_pv1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:03.817108 [ 8172 ] {d89623f4-3985-4604-a404-f9f32fba7143} executeQuery: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34606) (comment: 02428_parameterized_view.sh) (in query: DROP TABLE test_02428_Catalog), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:03.837229 [ 8172 ] {d89623f4-3985-4604-a404-f9f32fba7143} TCPHandler: Code: 60. DB::Exception: Table test_11.test_02428_Catalog does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:04.117330 [ 4197 ] {0fbcee87-5400-4d0b-af59-0cfefd5fd21a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34598) (comment: 01936_quantiles_cannot_return_null.sql) (in query: SELECT quantiles(0.95)(x) FROM (SELECT 1 x WHERE 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:04.129006 [ 4197 ] {0fbcee87-5400-4d0b-af59-0cfefd5fd21a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:04.371348 [ 6398 ] {77c4afd5-aded-4d4c-89dd-edadd9d82674} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34748) (comment: 02428_parameterized_view.sh) (in query: DROP TABLE 02428_parameterized_view_test_11.pv1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:04.374269 [ 6398 ] {77c4afd5-aded-4d4c-89dd-edadd9d82674} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:05.093397 [ 3832 ] {04dc8131-fbc6-4ed6-800c-70580b4643f4} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string1').). 2025.06.25 16:13:05.135897 [ 6836 ] {4b1ed790-d98f-4c62-8b43-6cdbac815d5d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34812) (comment: 02428_parameterized_view.sh) (in query: DROP DATABASE 02428_parameterized_view_test_11), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:13:05.161098 [ 6836 ] {4b1ed790-d98f-4c62-8b43-6cdbac815d5d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:13:05.858885 [ 6836 ] {2ffd443a-4f5a-461a-b127-23f5723ddaff} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view.sh) (in query: /* ddl_entry=query-0000000035 */ TRUNCATE VIEW test_11.`02428_trace_view`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:05.897495 [ 6836 ] {2ffd443a-4f5a-461a-b127-23f5723ddaff} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34838) (comment: 02428_parameterized_view.sh) (in query: DROP VIEW 02428_trace_view), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:05.919373 [ 6836 ] {2ffd443a-4f5a-461a-b127-23f5723ddaff} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:05.953007 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8615fb30-d08c-48c1-a41a-01099e1320ba::202506_1_25_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:06.286041 [ 4191 ] {842bab10-2e5a-4c68-ab1e-a4fb62276d8b} executeQuery: Code: 60. DB::Exception: Table test_11.`02428_otel_traces_trace_id_ts` does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34864) (comment: 02428_parameterized_view.sh) (in query: DROP TABLE 02428_otel_traces_trace_id_ts), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:06.314527 [ 4191 ] {842bab10-2e5a-4c68-ab1e-a4fb62276d8b} TCPHandler: Code: 60. DB::Exception: Table test_11.`02428_otel_traces_trace_id_ts` does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:06.613378 [ 6398 ] {733fab5c-5289-46ce-be80-3d0649fb35d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34828) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:06.618127 [ 6398 ] {733fab5c-5289-46ce-be80-3d0649fb35d3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:06.835579 [ 5056 ] {ab2632ac-ca90-4f80-9cf1-da8dfba2ba3f} executeQuery: Code: 60. DB::Exception: Table test_11.`02428_otel_traces` does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34882) (comment: 02428_parameterized_view.sh) (in query: DROP TABLE 02428_otel_traces), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:06.873781 [ 5056 ] {ab2632ac-ca90-4f80-9cf1-da8dfba2ba3f} TCPHandler: Code: 60. DB::Exception: Table test_11.`02428_otel_traces` does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:07.713430 [ 6985 ] {c0892a6f-573e-449c-99f5-da2868d528c3} executeQuery: Code: 549. DB::Exception: Column `m1` with type Map(Nothing, String) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: /* ddl_entry=query-0000000036 */ CREATE TABLE test_11.tab UUID 'b843e8a6-d523-4747-9ca0-a130cd2c6148' (`m1` Map(Nothing, String)) ENGINE = MergeTree ORDER BY m1 SETTINGS index_granularity = 3394, min_bytes_for_wide_part = 974520779, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 401225123, compact_parts_max_bytes_to_buffer = 299801990, compact_parts_max_granules_to_buffer = 158, compact_parts_merge_max_bytes_to_prefetch_part = 28181219, merge_max_block_size = 738, old_parts_lifetime = 322., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1538477, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 34036, primary_key_compress_block_size = 83250), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Storages/KeyDescription.cpp:0: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000012203def 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a70100 6. /build/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 @ 0x00000000122537c7 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 13. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 15. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:07.734358 [ 6985 ] {c0892a6f-573e-449c-99f5-da2868d528c3} executeQuery: Code: 549. DB::Exception: Column `m1` with type Map(Nothing, String) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34912) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: CREATE TABLE tab (`m1` Map(Nothing, String)) ENGINE = MergeTree ORDER BY m1 SETTINGS index_granularity = 3394, min_bytes_for_wide_part = 974520779, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 401225123, compact_parts_max_bytes_to_buffer = 299801990, compact_parts_max_granules_to_buffer = 158, compact_parts_merge_max_bytes_to_prefetch_part = 28181219, merge_max_block_size = 738, old_parts_lifetime = 322., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1538477, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 34036, primary_key_compress_block_size = 83250), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Storages/KeyDescription.cpp:0: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000012203def 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a70100 6. /build/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 @ 0x00000000122537c7 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 13. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 15. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:07.735735 [ 6985 ] {c0892a6f-573e-449c-99f5-da2868d528c3} TCPHandler: Code: 549. DB::Exception: Column `m1` with type Map(Nothing, String) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Storages/KeyDescription.cpp:0: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000012203def 5. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:671: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a70100 6. /build/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 @ 0x00000000122537c7 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 13. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 14. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 15. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 18. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:08.523481 [ 6379 ] {1d083174-f3cc-4150-8453-f6d1499c1a7c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34898) (comment: 03033_recursive_cte_basic.sql) (in query: SELECT '--';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:08.525267 [ 6379 ] {1d083174-f3cc-4150-8453-f6d1499c1a7c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:08.835586 [ 6985 ] {7ea95118-fee8-43c5-ac45-b16af990077f} executeQuery: Code: 57. DB::Exception: Table test_11.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: /* ddl_entry=query-0000000039 */ CREATE TABLE test_11.tab UUID 'c10d047f-e5e4-4c51-a2e1-b616c6480c1e' (`m1` Map(Float32, String), `m2` Map(LowCardinality(String), String)) ENGINE = MergeTree ORDER BY (m1, m2) SETTINGS index_granularity = 3394, min_bytes_for_wide_part = 974520779, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 401225123, compact_parts_max_bytes_to_buffer = 299801990, compact_parts_max_granules_to_buffer = 158, compact_parts_merge_max_bytes_to_prefetch_part = 28181219, merge_max_block_size = 738, old_parts_lifetime = 322., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1538477, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 34036, primary_key_compress_block_size = 83250), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:08.929464 [ 6985 ] {7ea95118-fee8-43c5-ac45-b16af990077f} executeQuery: Code: 57. DB::Exception: Table test_11.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34912) (comment: 03034_ddls_and_merges_with_unusual_maps.sql) (in query: CREATE TABLE tab (`m1` Map(Float32, String), `m2` Map(LowCardinality(String), String)) ENGINE = MergeTree ORDER BY (m1, m2) SETTINGS index_granularity = 3394, min_bytes_for_wide_part = 974520779, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 401225123, compact_parts_max_bytes_to_buffer = 299801990, compact_parts_max_granules_to_buffer = 158, compact_parts_merge_max_bytes_to_prefetch_part = 28181219, merge_max_block_size = 738, old_parts_lifetime = 322., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 1538477, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 34036, primary_key_compress_block_size = 83250), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:08.930728 [ 6985 ] {7ea95118-fee8-43c5-ac45-b16af990077f} TCPHandler: Code: 57. DB::Exception: Table test_11.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:09.156498 [ 6379 ] {f9000e05-11bd-429a-a580-78951da5e590} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57638) (comment: 00800_low_cardinality_array_group_by_arg.sql) (in query: DROP DATABASE IF EXISTS test_tnrld1a5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:09.162930 [ 6379 ] {f9000e05-11bd-429a-a580-78951da5e590} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:09.245042 [ 2956 ] {8d59630a-1391-4921-b898-2911bb869265} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57642) (comment: 00800_low_cardinality_array_group_by_arg.sql) (in query: DROP DATABASE IF EXISTS test_tnrld1a5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:09.253198 [ 2956 ] {8d59630a-1391-4921-b898-2911bb869265} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:09.313252 [ 5054 ] {f365da23-8c1c-44a8-b095-6e959358cf30} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57656) (comment: 00800_low_cardinality_array_group_by_arg.sql) (in query: DROP DATABASE IF EXISTS test_tnrld1a5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:09.316130 [ 5054 ] {f365da23-8c1c-44a8-b095-6e959358cf30} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:09.407046 [ 3832 ] {4e8ed641-740c-4d2d-ada5-93c9826f56a8} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (3) differs with number of rows with sign = -1 (0) by more than one (for key: 'string2').). 2025.06.25 16:13:09.447014 [ 3832 ] {4e8ed641-740c-4d2d-ada5-93c9826f56a8} MergeTreeDataWriter: Incorrect data: number of rows with sign = 1 (2) differs with number of rows with sign = -1 (0) by more than one (for key: 'string2').). 2025.06.25 16:13:09.567780 [ 4191 ] {3a956ec5-c4b7-4519-b284-f2759d7c4e0b} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34918) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:09.577803 [ 4191 ] {3a956ec5-c4b7-4519-b284-f2759d7c4e0b} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:09.617155 [ 4191 ] {bb2af6d1-aa50-46f9-a5fd-969b9a785dd2} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34918) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:09.626332 [ 4191 ] {bb2af6d1-aa50-46f9-a5fd-969b9a785dd2} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:09.689891 [ 4191 ] {dc4b72c1-9159-44ca-b828-44a62f72eb57} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34918) (comment: 01013_totals_without_aggregation.sql) (in query: SELECT 1 AS n WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:09.697033 [ 4191 ] {dc4b72c1-9159-44ca-b828-44a62f72eb57} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000110844a1 5. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110338ae 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:12.008842 [ 6985 ] {94d5a766-174e-411a-84e4-dac40e6b9e7c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34976) (comment: 01271_optimize_arithmetic_operations_in_aggr_func_with_alias.sql) (in query: select min((n as a) + (1 as b)) c from (select number n from numbers(10)) where a > 0 and b > 0 having c > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:12.023714 [ 6985 ] {94d5a766-174e-411a-84e4-dac40e6b9e7c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:12.916560 [ 4006 ] {ca46d962-774f-48dd-b2f9-de0638f3c252} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57760) (comment: 02483_check_virtuals_shile_using_structure_from_insertion_table.sql) (in query: DROP DATABASE IF EXISTS test_bea8byw2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:12.923647 [ 4006 ] {ca46d962-774f-48dd-b2f9-de0638f3c252} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:13.497572 [ 5056 ] {0f1ba078-ce59-448c-87ce-5b453e93c07b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34902) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906f7e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:13.512850 [ 5056 ] {0f1ba078-ce59-448c-87ce-5b453e93c07b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906f7e 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:13.708289 [ 6986 ] {02a3b855-fbf4-492b-92af-b79fe17584b4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57772) (comment: 00996_limit_with_ties.sql) (in query: DROP DATABASE IF EXISTS test_8p2tpvcf ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:13.727320 [ 6986 ] {02a3b855-fbf4-492b-92af-b79fe17584b4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.088723 [ 4006 ] {30f0fe63-b2ac-4615-be18-2edbc37906b5} DatabaseReplicated (test_37ltpwcz): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:13:15.101030 [ 4006 ] {30f0fe63-b2ac-4615-be18-2edbc37906b5} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45654) (comment: 01901_test_attach_partition_from.sql) (in query: CREATE TABLE test_alter_attach_01901D (`A` Int64, `D` date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_alter_attach_01901D', 'r1') PARTITION BY D ORDER BY A SETTINGS index_granularity = 21566, min_bytes_for_wide_part = 756473006, ratio_of_defaults_for_sparse_serialization = 0.08969032764434814, replace_long_file_name_to_hash = true, max_file_name_length = 14, min_bytes_for_full_part_storage = 309114976, compact_parts_max_bytes_to_buffer = 400880130, compact_parts_max_granules_to_buffer = 156, compact_parts_merge_max_bytes_to_prefetch_part = 21210014, merge_max_block_size = 4027, 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 = 10737418240, index_granularity_bytes = 9938555, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 86092, primary_key_compress_block_size = 57849), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:15.102448 [ 5196 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-25 16:13:20: Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.104381 [ 5774 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-25 16:13:20: Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.106165 [ 5785 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-25 16:13:21: Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.108014 [ 4006 ] {30f0fe63-b2ac-4615-be18-2edbc37906b5} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:15.108383 [ 5775 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-25 16:13:20: Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.155102 [ 5174 ] {e450d8f8-8c83-43eb-b297-39e4af64185e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(30)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45756) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(30));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.155263 [ 6836 ] {714f4c6d-ee14-4d4a-acb1-dd9a1480b1ce} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45774) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(33));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.155601 [ 2956 ] {ccf16fe3-af1c-4584-b9ad-97b79dc0769b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45740) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(97));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.156974 [ 6985 ] {b9539dc1-c792-4258-9f2b-4ec0b294cc0d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45728) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(65));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.165516 [ 5174 ] {e450d8f8-8c83-43eb-b297-39e4af64185e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(30)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.165925 [ 2956 ] {ccf16fe3-af1c-4584-b9ad-97b79dc0769b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.174409 [ 6985 ] {b9539dc1-c792-4258-9f2b-4ec0b294cc0d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.177303 [ 6836 ] {714f4c6d-ee14-4d4a-acb1-dd9a1480b1ce} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(33)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.258138 [ 6665 ] {4c796524-4627-434d-a740-62cdbe64e464} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51814) (comment: 01901_test_attach_partition_from.sql) (in query: DROP DATABASE IF EXISTS test_37ltpwcz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:15.262086 [ 6665 ] {4c796524-4627-434d-a740-62cdbe64e464} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.348296 [ 6985 ] {3e8fcbca-f581-4046-aece-581e371bb21d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51824) (comment: 01901_test_attach_partition_from.sql) (in query: DROP DATABASE IF EXISTS test_37ltpwcz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:15.351120 [ 6985 ] {3e8fcbca-f581-4046-aece-581e371bb21d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.405218 [ 2956 ] {2e56f98b-9f47-42ff-880e-b4e668f048f1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51826) (comment: 01901_test_attach_partition_from.sql) (in query: DROP DATABASE IF EXISTS test_37ltpwcz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:15.410885 [ 2956 ] {2e56f98b-9f47-42ff-880e-b4e668f048f1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.494727 [ 6985 ] {e8bf873b-280e-4485-a352-ddcac4c69fe1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51828) (comment: 01901_test_attach_partition_from.sql) (in query: DROP DATABASE IF EXISTS test_37ltpwcz ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:15.518888 [ 6985 ] {e8bf873b-280e-4485-a352-ddcac4c69fe1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:15.896614 [ 6985 ] {9470faa0-3217-4dbb-a982-97ebf4970162} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(78)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45830) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(78));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:15.911529 [ 6985 ] {9470faa0-3217-4dbb-a982-97ebf4970162} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(78)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.251095 [ 5174 ] {e63645a5-90df-43ee-816c-6da6187f120a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45848) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(25));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.267758 [ 5174 ] {e63645a5-90df-43ee-816c-6da6187f120a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.272742 [ 4197 ] {efb0f8c9-cf7a-4a85-9c7f-054355bf1630} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45862) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(12));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.308317 [ 4197 ] {efb0f8c9-cf7a-4a85-9c7f-054355bf1630} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(12)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.333784 [ 2956 ] {467daaab-7527-4c16-8ab7-fb4e792d7d6d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(81)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45836) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(81));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.346435 [ 2956 ] {467daaab-7527-4c16-8ab7-fb4e792d7d6d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(81)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.531080 [ 2956 ] {a7f54593-6d99-4b5e-b163-edacdf502d85} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45882) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:16.548796 [ 2956 ] {a7f54593-6d99-4b5e-b163-edacdf502d85} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:16.756277 [ 2956 ] {853eec54-94ad-4424-bf43-71de1a913f78} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45908) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(71));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:16.770112 [ 2956 ] {853eec54-94ad-4424-bf43-71de1a913f78} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.086556 [ 5174 ] {b13276b1-1541-4b01-9646-4082c4a37c34} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(63)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45970) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(63));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.122456 [ 5174 ] {b13276b1-1541-4b01-9646-4082c4a37c34} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(63)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.149775 [ 6836 ] {d1f0967b-6059-4e8f-a023-c047f30a8168} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(42)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45996) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(42));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.158645 [ 6836 ] {d1f0967b-6059-4e8f-a023-c047f30a8168} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(42)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.158859 [ 4197 ] {951d1f49-a52a-4153-a403-a6e3084716d3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45980) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(72));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.172502 [ 4197 ] {951d1f49-a52a-4153-a403-a6e3084716d3} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.445439 [ 4006 ] {08f1858a-af05-40cf-81d0-9c5809dbbef1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46004) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(39));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.448345 [ 4006 ] {08f1858a-af05-40cf-81d0-9c5809dbbef1} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.520998 [ 6985 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:17.543771 [ 2952 ] {6499d814-d930-4c98-b2e0-32294ff60665} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34938) (comment: 00836_indices_alter.sql) (in query: SELECT * FROM minmax_idx2 WHERE u64 * i32 = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:13:17.547214 [ 2952 ] {6499d814-d930-4c98-b2e0-32294ff60665} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:13:17.843533 [ 4006 ] {47f68c22-ae5e-44a3-b159-7c7a98f4bfef} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(56)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46048) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(56));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.851345 [ 4006 ] {47f68c22-ae5e-44a3-b159-7c7a98f4bfef} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(56)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.869466 [ 5174 ] {86f76f95-7b2c-477a-b043-d3c138fd197e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(18)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46064) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(18));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.881978 [ 5174 ] {86f76f95-7b2c-477a-b043-d3c138fd197e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(18)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:17.899633 [ 2956 ] {8f9571c0-1585-4ef1-aae1-b204687ed4e8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46044) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: SELECT rand() % 100;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:17.909728 [ 2956 ] {8f9571c0-1585-4ef1-aae1-b204687ed4e8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:18.059553 [ 4006 ] {28280922-158a-48ff-8d5f-dab499ff4db9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51866) (comment: 01737_move_order_key_to_prewhere_select_final.sql) (in query: DROP DATABASE IF EXISTS test_ufx3ybqs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:18.062864 [ 4006 ] {28280922-158a-48ff-8d5f-dab499ff4db9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:18.107050 [ 6985 ] {1dad091e-6e67-438d-8314-19d052c307e5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51850) (comment: 02245_s3_virtual_columns.sql) (in query: DROP DATABASE IF EXISTS test_xez9t3f5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:18.112393 [ 6985 ] {1dad091e-6e67-438d-8314-19d052c307e5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:18.125277 [ 6836 ] {e439dfd6-f263-4af1-9e1e-3fd1938570da} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46098) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(65));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:18.151890 [ 2956 ] {318f8911-c52a-433e-abba-35bcd13ca321} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51882) (comment: 01737_move_order_key_to_prewhere_select_final.sql) (in query: DROP DATABASE IF EXISTS test_ufx3ybqs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:18.154967 [ 6836 ] {e439dfd6-f263-4af1-9e1e-3fd1938570da} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(65)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:18.154889 [ 2956 ] {318f8911-c52a-433e-abba-35bcd13ca321} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:18.331723 [ 6836 ] {d20764d2-601f-474f-9256-ab4e6188bb6b} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46154) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:18.353227 [ 6836 ] {d20764d2-601f-474f-9256-ab4e6188bb6b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:18.410865 [ 2956 ] {442c8a4b-a92c-4ad3-b45c-9450f8c41c79} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46142) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:18.441413 [ 2956 ] {442c8a4b-a92c-4ad3-b45c-9450f8c41c79} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:18.595195 [ 2956 ] {4dc22a60-ee05-4c58-8b96-e6302f804fef} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(43)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46188) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(43));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:18.605078 [ 2956 ] {4dc22a60-ee05-4c58-8b96-e6302f804fef} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(43)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:18.624125 [ 6398 ] {d07228a1-3292-44f1-bcc3-7a73e1cf8134} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(6)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46200) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(6));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:18.641967 [ 6398 ] {d07228a1-3292-44f1-bcc3-7a73e1cf8134} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(6)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.006538 [ 4006 ] {441676e1-a2ae-4b02-a04b-a2e9fd517144} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46250) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: SELECT rand() % 100;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:19.007543 [ 6836 ] {b2a5343a-f897-4eec-8050-86c101c9eff9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46254) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.019503 [ 4006 ] {441676e1-a2ae-4b02-a04b-a2e9fd517144} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:19.035886 [ 6836 ] {b2a5343a-f897-4eec-8050-86c101c9eff9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.172771 [ 4006 ] {c3bbedfa-9813-41c5-aa23-68f64106ba55} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46264) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(74));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.205601 [ 4006 ] {c3bbedfa-9813-41c5-aa23-68f64106ba55} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.294621 [ 5174 ] {e025aeea-0bec-4188-b499-fa126578a785} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(80)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46276) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(80));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.317410 [ 5174 ] {e025aeea-0bec-4188-b499-fa126578a785} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(80)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.333807 [ 6836 ] {34109bc8-f75a-420b-abb0-1e0b455a257f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46306) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:19.349054 [ 6836 ] {34109bc8-f75a-420b-abb0-1e0b455a257f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:19.436203 [ 5174 ] {a392a020-3168-4b10-a6e6-3db962ef671f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46310) (comment: 02342_window_view_different_struct.sql) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:19.445270 [ 5174 ] {a392a020-3168-4b10-a6e6-3db962ef671f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:19.676096 [ 6155 ] {9fb974c2-88be-4acd-bd04-44138a2d5c24} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46332) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: SELECT rand() % 100;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:19.682983 [ 4191 ] {83ce18c2-b0c5-4dc3-958e-9cad6a0340bf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(82)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46348) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(82));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.687923 [ 6155 ] {9fb974c2-88be-4acd-bd04-44138a2d5c24} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:19.709052 [ 4191 ] {83ce18c2-b0c5-4dc3-958e-9cad6a0340bf} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(82)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.839986 [ 4006 ] {fd710748-7378-49fe-b223-2e5d9b4263f8} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(11)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46358) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(11));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.859955 [ 4006 ] {fd710748-7378-49fe-b223-2e5d9b4263f8} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(11)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.882517 [ 6155 ] {c082b0ef-a3e9-48ed-a850-f2f265f74b1e} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46368) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:19.885131 [ 6155 ] {c082b0ef-a3e9-48ed-a850-f2f265f74b1e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:19.895819 [ 6398 ] {d1a52641-03cd-47c9-946c-cedcc7e2c9e3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46360) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(25));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.921142 [ 6398 ] {d1a52641-03cd-47c9-946c-cedcc7e2c9e3} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(25)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:19.983218 [ 4006 ] {f6c85fc6-74ed-497e-8a3b-33468e277d21} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46394) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:19.993345 [ 4006 ] {f6c85fc6-74ed-497e-8a3b-33468e277d21} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/src/Functions/FunctionsConversion.cpp:0: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000071502b8 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000714a75b 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:20.486112 [ 4006 ] {fee20031-b65f-4735-a2e3-670f361bfdb3} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46458) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(21));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.553491 [ 4006 ] {fee20031-b65f-4735-a2e3-670f361bfdb3} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(21)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.660302 [ 6155 ] {1bcf6ec4-1a79-4921-a3bb-9a935bb800e2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46484) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(97));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.662233 [ 6398 ] {0feaaa79-3cb7-41c9-99f0-1f7b7634e2f0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46472) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(77));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.681815 [ 6155 ] {1bcf6ec4-1a79-4921-a3bb-9a935bb800e2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(97)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.688879 [ 6398 ] {0feaaa79-3cb7-41c9-99f0-1f7b7634e2f0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(77)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.725957 [ 4006 ] {60b02713-74f8-4a87-8fdf-2d54d9988f12} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(37)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46494) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(37));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.737086 [ 4006 ] {60b02713-74f8-4a87-8fdf-2d54d9988f12} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:20. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(37)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:20.804654 [ 4197 ] {e028269d-050b-4fcd-b0f0-92eca44c9186} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46086) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE (1, value) = (id, 'A');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:20.811203 [ 4197 ] {e028269d-050b-4fcd-b0f0-92eca44c9186} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:21.217115 [ 3213 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:21.219317 [ 2956 ] {ce0509e4-2694-41e7-ab9b-84333ee3f3ab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46232) (comment: 01639_distributed_sync_insert_zero_rows.sql) (in query: SELECT count() FROM distributed;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:21.220611 [ 5196 ] {} ExternalDictionaries: Could not update cache dictionary 'one_cell_cache_ints', next update is scheduled at 2025-06-25 16:13:33: Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:21.223273 [ 2956 ] {ce0509e4-2694-41e7-ab9b-84333ee3f3ab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:21.242910 [ 8125 ] {3b14530f-b79d-49aa-9433-4b6e7839392a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46558) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.247915 [ 8125 ] {3b14530f-b79d-49aa-9433-4b6e7839392a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Update failed for dictionary one_cell_cache_ints : Code: 81. DB::Exception: Database test_01054 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/Context.cpp:5095: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcd58 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089965 7. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 16. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000c91e6f5 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000c91ead1 21. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb7622a 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(10)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.285103 [ 3998 ] {051cf2cf-1981-4e11-a747-6295b0f96f35} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(23)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46566) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(23));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.313171 [ 3998 ] {051cf2cf-1981-4e11-a747-6295b0f96f35} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(23)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.412594 [ 4006 ] {f1b07c00-749d-4020-8076-96c3970f90c0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46572) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(71));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.422412 [ 4006 ] {f1b07c00-749d-4020-8076-96c3970f90c0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(71)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.515365 [ 4191 ] {c7726fdd-0f13-479c-9c4e-296c7ce8dd14} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46576) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(72));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.536525 [ 4191 ] {c7726fdd-0f13-479c-9c4e-296c7ce8dd14} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:21.983203 [ 6665 ] {72f387a2-676d-4616-a065-295f74b06cfa} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(73)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46642) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(73));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.001303 [ 6665 ] {72f387a2-676d-4616-a065-295f74b06cfa} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(73)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.070073 [ 2952 ] {dd345c39-07f0-4a85-9ebb-7134dc7619ff} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(2)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46658) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(2));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.101013 [ 2952 ] {dd345c39-07f0-4a85-9ebb-7134dc7619ff} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(2)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.222928 [ 6665 ] {7d6b0ac8-9ae0-4989-9bb3-b07192cfca3a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46670) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(74));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.244561 [ 6665 ] {7d6b0ac8-9ae0-4989-9bb3-b07192cfca3a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(74)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.272678 [ 6985 ] {cbec6bdf-5d90-49a3-86b5-99cfd3f8b77e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(96)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46686) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(96));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.281135 [ 6985 ] {cbec6bdf-5d90-49a3-86b5-99cfd3f8b77e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(96)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.794736 [ 6665 ] {1940d784-52c5-4355-b762-deb26a4c44e0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46738) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(39));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.795361 [ 6155 ] {59419469-2580-4049-8a4a-70d8bef77636} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111e1b3a 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685862 9. /build/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&) @ 0x000000001166e306 10. /build/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&) @ 0x0000000011662ec2 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 13. /build/contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000001166619d 14. /build/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&) @ 0x000000001166245c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000011649670 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116464e6 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:22.805119 [ 6665 ] {1940d784-52c5-4355-b762-deb26a4c44e0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(39)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.843438 [ 2952 ] {ff0c666a-0fee-4487-b846-9954c9c45c77} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46742) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(17));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.857116 [ 2952 ] {ff0c666a-0fee-4487-b846-9954c9c45c77} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:22.899718 [ 6155 ] {59419469-2580-4049-8a4a-70d8bef77636} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46554) (comment: 03123_analyzer_dist_join_CTE.sql) (in query: SELECT * FROM ( WITH b AS ( SELECT toInt64(number) AS a FROM numbers(10) ), c AS ( SELECT toInt64(number) AS a FROM numbers(10) ) SELECT * FROM dist_t0 AS a LEFT JOIN b AS b ON a.a = b.a LEFT JOIN c AS c ON a.a = c.a ) ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111e1b3a 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685862 9. /build/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&) @ 0x000000001166e306 10. /build/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&) @ 0x0000000011662ec2 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 13. /build/contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000001166619d 14. /build/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&) @ 0x000000001166245c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000011649670 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116464e6 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:22.909738 [ 6155 ] {59419469-2580-4049-8a4a-70d8bef77636} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111e1b3a 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685862 9. /build/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&) @ 0x000000001166e306 10. /build/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&) @ 0x0000000011662ec2 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 13. /build/contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000001166619d 14. /build/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&) @ 0x000000001166245c 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000011649670 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000116464e6 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:23.053184 [ 6665 ] {94ef2236-5448-4f4a-be74-c8530d6d1913} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(42)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46760) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(42));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.057368 [ 6665 ] {94ef2236-5448-4f4a-be74-c8530d6d1913} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(42)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.085682 [ 4191 ] {9bf4083c-a645-4b07-92e7-a380b7c6d522} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46746) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(17));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.088179 [ 4191 ] {9bf4083c-a645-4b07-92e7-a380b7c6d522} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(17)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.305687 [ 8172 ] {ed1f5dd8-933c-4edb-81f0-a4b988a03ff5} 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.10505.altinitytest (altinity build)) (from [::1]:45782) (comment: 03146_asof_join_ddb_merge_long.gen.sql) (in query: -- TODO: enable once USING and `join_use_nulls` is supported by `full_sorting_merge` -- SET join_use_nulls = 1; WITH build AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:00') + INTERVAL i.number SECONDS AS t, i.number % 37 AS v FROM numbers(3000000) AS i CROSS JOIN numbers(2) AS tk SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ), probe AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:30') + INTERVAL tt.number HOUR AS t FROM numbers(2) AS tk CROSS JOIN numbers(toUInt32((toDateTime('2021-02-01 00:00:30') - toDateTime('2021-01-01 00:00:30')) / 3600)) AS tt SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ) SELECT SUM(v) AS v, COUNT(*) AS n FROM probe ASOF LEFT JOIN build USING (k, t) ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:23.315458 [ 8172 ] {ed1f5dd8-933c-4edb-81f0-a4b988a03ff5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:23.471250 [ 6379 ] {6fc49fab-e8c1-413c-9502-c129c9d6162a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(0)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46818) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.497473 [ 6379 ] {6fc49fab-e8c1-413c-9502-c129c9d6162a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(0)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.518143 [ 6986 ] {42fbe003-538e-49c3-8bc4-32bf6a346e6e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46826) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(94));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.546650 [ 6986 ] {42fbe003-538e-49c3-8bc4-32bf6a346e6e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(94)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.637427 [ 4191 ] {924ab714-02de-45b4-ab2c-61127892e1ca} executeQuery: Code: 137. DB::Exception: Unknown dictionary layout type: iptrie. (UNKNOWN_ELEMENT_IN_CONFIG) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01256_misspell_layout_name_podshumok.sql) (in query: /* ddl_entry=query-0000000052 */ CREATE DICTIONARY test_11.testip UUID 'c883a4af-f7cf-4308-9966-363fdebcbf39' (`network` String, `test_field` String) PRIMARY KEY network SOURCE(FILE(PATH '/tmp/test.csv' FORMAT CSVWithNames)) LIFETIME(MIN 0 MAX 300) LAYOUT(IPTRIE())), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Dictionaries/DictionaryFactory.cpp:74: DB::DictionaryFactory::isComplex(String const&) const @ 0x00000000104b1d37 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000010d92dab 6. /build/src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001222d982 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 14. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 16. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:23.686201 [ 4191 ] {924ab714-02de-45b4-ab2c-61127892e1ca} executeQuery: Code: 137. DB::Exception: Unknown dictionary layout type: iptrie. (UNKNOWN_ELEMENT_IN_CONFIG) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46770) (comment: 01256_misspell_layout_name_podshumok.sql) (in query: CREATE DICTIONARY testip ( `network` String, `test_field` String ) PRIMARY KEY network SOURCE(FILE(PATH '/tmp/test.csv' FORMAT CSVWithNames)) LIFETIME(MIN 0 MAX 300) LAYOUT(IPTRIE());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Dictionaries/DictionaryFactory.cpp:74: DB::DictionaryFactory::isComplex(String const&) const @ 0x00000000104b1d37 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000010d92dab 6. /build/src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001222d982 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 14. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 16. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:23.687426 [ 4191 ] {924ab714-02de-45b4-ab2c-61127892e1ca} TCPHandler: Code: 137. DB::Exception: Unknown dictionary layout type: iptrie. (UNKNOWN_ELEMENT_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Dictionaries/DictionaryFactory.cpp:74: DB::DictionaryFactory::isComplex(String const&) const @ 0x00000000104b1d37 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:0: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000010d92dab 6. /build/src/Storages/StorageDictionary.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001222d982 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 14. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 16. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:23.819700 [ 6665 ] {0afd054f-b8b2-4c5b-8db9-4d04c0ceb0f2} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(86)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46842) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(86));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.837263 [ 6665 ] {0afd054f-b8b2-4c5b-8db9-4d04c0ceb0f2} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(86)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.919143 [ 6379 ] {7f69fb9f-b2be-4747-be0c-418c1efd666f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(99)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46866) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(99));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:23.945057 [ 6379 ] {7f69fb9f-b2be-4747-be0c-418c1efd666f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(99)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:24.243525 [ 4197 ] {dc7c5638-e77c-4a98-aa55-22a8792823d9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(83)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43166) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(83));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:24.249092 [ 4197 ] {dc7c5638-e77c-4a98-aa55-22a8792823d9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(83)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:24.287450 [ 5054 ] {f2861c3d-d5ad-4cad-81e5-66b04735153e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43178) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: select dictGet('one_cell_cache_ints', 'i8', toUInt64(72));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:24.349201 [ 4027 ] {593073b5-3fab-4f84-804a-3d6027fd98be} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43172). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43172) (comment: 01054_cache_dictionary_bunch_update.sh) (in query: SELECT rand() % 100;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:13:24.464606 [ 4027 ] {593073b5-3fab-4f84-804a-3d6027fd98be} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43172). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:24.466050 [ 4027 ] {593073b5-3fab-4f84-804a-3d6027fd98be} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43172). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:13:24.468707 [ 4027 ] {593073b5-3fab-4f84-804a-3d6027fd98be} TCPHandler: Client has gone away. 2025.06.25 16:13:24.477846 [ 5054 ] {f2861c3d-d5ad-4cad-81e5-66b04735153e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'one_cell_cache_ints': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary one_cell_cache_ints now, because nearest update is scheduled at 2025-06-25 16:13:33. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Dictionaries/CacheDictionary.cpp:0: DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000000cb77951 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000000cb81870 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000000cb83e21 7. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 8. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGet('one_cell_cache_ints', 'i8', toUInt64(72)). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000000cb83bba 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb72e81 6. /build/contrib/llvm-project/libcxx/include/vector:553: DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000000cb723b6 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x00000000073fc65f 8. /build/src/Functions/FunctionsExternalDictionaries.h:611: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f99ad 9. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 10. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:13:24.481975 [ 5054 ] {f2861c3d-d5ad-4cad-81e5-66b04735153e} TCPHandler: Client has gone away. 2025.06.25 16:13:25.170399 [ 4027 ] {1659624a-392e-4de5-9a23-2a7354477005} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43248) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.172574 [ 4027 ] {1659624a-392e-4de5-9a23-2a7354477005} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.188571 [ 6836 ] {e212a989-5db1-47d8-835d-63adb7106984} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43284) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.190789 [ 6836 ] {e212a989-5db1-47d8-835d-63adb7106984} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.190917 [ 5054 ] {5836a60b-3534-46ab-a49a-5a84c94d713f} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43250) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.208322 [ 8172 ] {dd4ae990-91b1-440f-a600-c58e07485d8c} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43300) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.217273 [ 5054 ] {5836a60b-3534-46ab-a49a-5a84c94d713f} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.221602 [ 8172 ] {dd4ae990-91b1-440f-a600-c58e07485d8c} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.246513 [ 4191 ] {5e348291-2d5c-45cc-93c6-f100af338205} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43302) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.249334 [ 4191 ] {5e348291-2d5c-45cc-93c6-f100af338205} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.258892 [ 4006 ] {0449a038-701b-4d33-b3ad-77d5746907bb} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43266) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.265285 [ 4006 ] {0449a038-701b-4d33-b3ad-77d5746907bb} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.296782 [ 6665 ] {092148ad-5d31-400a-8bdc-698ae39b9a41} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43306) (comment: 00941_system_columns_race_condition.sh) (in query: ALTER TABLE alter_table ADD COLUMN h String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.298545 [ 6665 ] {092148ad-5d31-400a-8bdc-698ae39b9a41} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:25.326949 [ 6398 ] {46fb6381-672e-417b-8beb-73ed90c6a78c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43280) (comment: 00941_system_columns_race_condition.sh) (in query: SELECT name FROM system.columns UNION ALL SELECT name FROM system.columns FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:25.330269 [ 6398 ] {46fb6381-672e-417b-8beb-73ed90c6a78c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=755, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:25.773723 [ 5054 ] {b0ce3872-76bb-4811-b359-53c8a76d24ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43346) (comment: 00012_sorting_distributed.sql) (in query: SELECT EventTime::DateTime('Asia/Dubai') FROM remote('127.0.0.{1,2}', test, hits) ORDER BY EventTime DESC LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:25.777311 [ 5054 ] {b0ce3872-76bb-4811-b359-53c8a76d24ad} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:25.916912 [ 2956 ] {2359088e-8ca7-47b0-becf-4165e7be8f98} executeQuery: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46888) (comment: 01071_force_optimize_skip_unused_shards.sql) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageDistributed.cpp:1502: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x00000000122337c7 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223276c 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116685d7 7. /build/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&) @ 0x000000001166245c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:25.920691 [ 2956 ] {2359088e-8ca7-47b0-becf-4165e7be8f98} TCPHandler: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageDistributed.cpp:1502: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x00000000122337c7 5. /build/src/Storages/StorageDistributed.cpp:402: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001223276c 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116685d7 7. /build/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&) @ 0x000000001166245c 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:26.325276 [ 3285 ] {} DatabaseCatalog: Cannot drop tables. 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:26.510679 [ 2956 ] {2c8ceae7-99b7-444e-bc7a-1327b987e3fe} executeQuery: Code: 57. DB::Exception: Table test_11.dist_01071 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01071_force_optimize_skip_unused_shards.sql) (in query: /* ddl_entry=query-0000000056 */ CREATE TABLE test_11.dist_01071 UUID '77107a93-0bee-47f1-bc1a-ea267eab455a' (`key` Int32) ENGINE = Distributed(test_cluster_two_shards, currentDatabase(), data_01071, key % 2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:26.563032 [ 2956 ] {2c8ceae7-99b7-444e-bc7a-1327b987e3fe} executeQuery: Code: 57. DB::Exception: Table test_11.dist_01071 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46888) (comment: 01071_force_optimize_skip_unused_shards.sql) (in query: create table dist_01071 as data_01071 Engine=Distributed(test_cluster_two_shards, currentDatabase(), data_01071, key%2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:26.564214 [ 2956 ] {2c8ceae7-99b7-444e-bc7a-1327b987e3fe} TCPHandler: Code: 57. DB::Exception: Table test_11.dist_01071 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:13:27.574215 [ 4197 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:27.675548 [ 5174 ] {bb3e24d6-a211-4037-b2c4-b3ea33d6a7a8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43382) (comment: 02014_dict_get_nullable_key.sql) (in query: DROP DICTIONARY test_dictionary_non_nullable;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:27.689795 [ 5174 ] {bb3e24d6-a211-4037-b2c4-b3ea33d6a7a8} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:27.865308 [ 6665 ] {8a2019d4-02f7-4345-b1ee-0010350ee41c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43438) (comment: 00941_system_columns_race_condition.sh) (in query: SELECT name FROM system.columns UNION ALL SELECT name FROM system.columns FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:27.877093 [ 6665 ] {8a2019d4-02f7-4345-b1ee-0010350ee41c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:28.121731 [ 6986 ] {fd04ba5b-0f99-4208-9bdd-aa147fdf24ec} executeQuery: Code: 15. DB::Exception: Column time specified more than once. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43456) (comment: 01032_duplicate_column_insert_query.sql) (in query: INSERT INTO sometable (date, time, value, time) VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x00000000115f590e 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000115f4eff 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8b8 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:28.134948 [ 6986 ] {fd04ba5b-0f99-4208-9bdd-aa147fdf24ec} TCPHandler: Code: 15. DB::Exception: Column time specified more than once. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x00000000115f590e 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000115f4eff 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8b8 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:28.223983 [ 2952 ] {ff17331b-b7f7-4665-8c21-9945e44ef58c} executeQuery: Code: 44. DB::Exception: Constant columns are not supported at the moment. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: -- Constant columns are currently not supported. SELECT runningConcurrency(toDate(arrayJoin([1, 2])), toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/runningConcurrency.cpp:40: DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5a8613 5. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 6. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 10. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 12. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 14. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 17. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 18. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:28.230178 [ 2952 ] {ff17331b-b7f7-4665-8c21-9945e44ef58c} TCPHandler: Code: 44. DB::Exception: Constant columns are not supported at the moment. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/runningConcurrency.cpp:40: DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5a8613 5. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 6. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 10. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 12. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 14. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 15. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 17. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 18. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:28.439674 [ 2952 ] {85552024-7fd7-4111-95b7-ab63095205ac} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency('strings are', 'not supported'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: -- Unsupported data types SELECT runningConcurrency('strings are', 'not supported');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:28.556786 [ 2952 ] {85552024-7fd7-4111-95b7-ab63095205ac} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency('strings are', 'not supported'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:28.623713 [ 2952 ] {dcaeefc7-2acb-4bdf-b817-5ab75e8ea6be} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: SELECT runningConcurrency(NULL, NULL);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:28.626722 [ 2952 ] {dcaeefc7-2acb-4bdf-b817-5ab75e8ea6be} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:28.646112 [ 4197 ] {a609471c-b2d5-4ea2-a99c-bd2c0578dc06} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39976) (comment: 02014_dict_get_nullable_key.sql) (in query: DROP DATABASE IF EXISTS test_6kav04bt ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:28.655309 [ 4197 ] {a609471c-b2d5-4ea2-a99c-bd2c0578dc06} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:28.801591 [ 2952 ] {75ea1b86-d7c3-4c8a-a083-2e36b2326530} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:28.806689 [ 2952 ] {75ea1b86-d7c3-4c8a-a083-2e36b2326530} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(CAST(NULL, 'Nullable(DateTime)'), CAST(NULL, 'Nullable(DateTime)')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: void DB::RunningConcurrencyOverloadResolver>::dispatchForSourceType>::buildImpl(std::vector> const&, std::shared_ptr const&) const::'lambda'(auto)>(DB::IDataType const&, auto&&) const @ 0x000000000b5a7264 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ed3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:29.004374 [ 2952 ] {660c66bd-3495-423c-9ba1-8b52ab7a2190} executeQuery: Code: 43. DB::Exception: Function runningConcurrency must be called with two arguments having the same type.: In scope SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: -- Mismatching data types SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ffb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:29.025625 [ 2952 ] {660c66bd-3495-423c-9ba1-8b52ab7a2190} TCPHandler: Code: 43. DB::Exception: Function runningConcurrency must be called with two arguments having the same type.: In scope SELECT runningConcurrency(toDate('2000-01-01'), toDateTime('2000-01-01 00:00:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/runningConcurrency.cpp:0: DB::RunningConcurrencyOverloadResolver>::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b5a6ffb 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:29.332914 [ 2952 ] {83b1a999-6a15-4015-a0b9-a2199afab396} executeQuery: Code: 117. DB::Exception: Incorrect order of events: '2000-01-02' > '2000-01-01': In scope SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01')). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01602_runningConcurrency.sql) (in query: -- begin > end SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000b5a89eb 4. /build/src/Functions/runningConcurrency.cpp:63: DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5a8578 5. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 6. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:13:29.340240 [ 2952 ] {83b1a999-6a15-4015-a0b9-a2199afab396} TCPHandler: Code: 117. DB::Exception: Incorrect order of events: '2000-01-02' > '2000-01-01': In scope SELECT runningConcurrency(toDate('2000-01-02'), toDate('2000-01-01')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000b5a89eb 4. /build/src/Functions/runningConcurrency.cpp:63: DB::ExecutableFunctionRunningConcurrency>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5a8578 5. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 6. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:13:30.673840 [ 4006 ] {10d97c22-0daa-4588-96ef-ed0d92100dd4} executeQuery: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43626) (comment: 01474_bad_global_join.sql) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000011066d2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110631b3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:13:30.704877 [ 4006 ] {10d97c22-0daa-4588-96ef-ed0d92100dd4} TCPHandler: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x0000000011066d2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110631b3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:13:31.718603 [ 6155 ] {ad8a901f-373e-4cc6-a3bf-0a6eda56be03} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43684) (comment: 00022_merge_prewhere.sql) (in query: DROP TABLE test.merge_hits;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:31.737868 [ 6155 ] {ad8a901f-373e-4cc6-a3bf-0a6eda56be03} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:32.533597 [ 5054 ] {8ce788f2-d601-4d1c-a7fb-4782e6c289fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=744). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43764) (comment: 00941_system_columns_race_condition.sh) (in query: SELECT name FROM system.columns UNION ALL SELECT name FROM system.columns FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:32.558955 [ 5054 ] {8ce788f2-d601-4d1c-a7fb-4782e6c289fd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=744). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:34.062316 [ 2956 ] {4980007a-e4e7-4435-b82e-36da2c2b238f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43784) (comment: 00182_simple_squashing_transform_bug.sql) (in query: SELECT sum(UserID GLOBAL IN (SELECT UserID FROM remote('127.0.0.{1,2}', test.hits))) FROM remote('127.0.0.{1,2}', test.hits);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000124ec603 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000124e99a0 13. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122363bc 14. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 15. /build/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&) @ 0x000000001166245c 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 17. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 18. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 19. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:34.077160 [ 2956 ] {4980007a-e4e7-4435-b82e-36da2c2b238f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000124ec603 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000124e99a0 13. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000122363bc 14. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 15. /build/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&) @ 0x000000001166245c 16. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 17. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 18. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 19. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:34.155542 [ 2952 ] {3302c235-68f5-4f6b-a877-3541f14bdd51} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43812) (comment: 00941_system_columns_race_condition.sh) (in query: SELECT name FROM system.columns UNION ALL SELECT name FROM system.columns FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:34.165224 [ 2952 ] {3302c235-68f5-4f6b-a877-3541f14bdd51} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:35.518248 [ 6985 ] {} DynamicQueryHandler: Code: 516. DB::Exception: header_test: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x000000001079d915 4. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x000000001171dbbe 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x0000000012cdd04a 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x0000000012c49d27 7. /build/src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4a0b0 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:35.759680 [ 6665 ] {} DynamicQueryHandler: Code: 516. DB::Exception: Got an empty user name from X-ClickHouse HTTP headers. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Server/HTTP/authenticateUserByHTTP.cpp:45: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x0000000012cdd6dc 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x0000000012c49d27 6. /build/src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4a0b0 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 8. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:36.541483 [ 6155 ] {ff365de4-339f-449b-a6dd-283abea8648d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42262) (comment: 01471_calculate_ttl_during_merge.sql) (in query: INSERT INTO table_for_ttl SELECT now() - INTERVAL 2 YEAR, 1, toString(number) from numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:36.550112 [ 6155 ] {ff365de4-339f-449b-a6dd-283abea8648d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:36.762605 [ 8172 ] {29c8fab2-f891-4b77-8f68-e38b7ff2c460} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44600) (comment: 01471_calculate_ttl_during_merge.sql) (in query: DROP DATABASE IF EXISTS test_s72lhh2t ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:36.778122 [ 8172 ] {29c8fab2-f891-4b77-8f68-e38b7ff2c460} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:37.416837 [ 6836 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database header_test does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000111789aa 5. /build/src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000110ea18a 6. /build/src/Server/HTTPHandler.cpp:365: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4bbf4 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 8. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:37.761670 [ 4191 ] {bdf291de-db27-4b7c-b8a0-641e02489ce1} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60928) (comment: 01399_http_request_headers.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x0000000012ce198d 5. /build/src/Formats/FormatFactory.cpp:500: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce37ea 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001191444d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:13:37.778938 [ 4191 ] {bdf291de-db27-4b7c-b8a0-641e02489ce1} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x0000000012ce198d 5. /build/src/Formats/FormatFactory.cpp:538: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce4285 6. /build/src/Interpreters/executeQuery.cpp:1497: 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 @ 0x0000000011916a23 7. /build/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&)>) @ 0x0000000011914d0c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:37.780302 [ 4191 ] {bdf291de-db27-4b7c-b8a0-641e02489ce1} DynamicQueryHandler: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x0000000012ce198d 5. /build/src/Formats/FormatFactory.cpp:500: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x0000000012ce37ea 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000001191444d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:38.224160 [ 6398 ] {0b1cf2eb-ea69-420d-a0a7-8f811191c103} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42340) (comment: 02152_csv_tuple.sql) (in query: insert into test_02152 select 1, 'Hello', [1,2,3], tuple(2, 'World', [4,5,6]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:38.249022 [ 6398 ] {0b1cf2eb-ea69-420d-a0a7-8f811191c103} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:38.478237 [ 6398 ] {41938e05-02c4-421c-8a35-9ff8f1162b95} executeQuery: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42362) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SET max_memory_usage='20G';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:38.500984 [ 6398 ] {41938e05-02c4-421c-8a35-9ff8f1162b95} TCPHandler: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:38.723047 [ 6398 ] {c6074f82-0475-4dd1-9539-9e965286a2e9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42402) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:38.763892 [ 6398 ] {c6074f82-0475-4dd1-9539-9e965286a2e9} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:40.357986 [ 4191 ] {ced9501d-41a8-4712-86e0-f0145145e6bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42458) (comment: 00140_rename.sql) (in query: SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4bce 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:40.391385 [ 4191 ] {ced9501d-41a8-4712-86e0-f0145145e6bd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4bce 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:13:40.627297 [ 6986 ] {88c3218f-6ef4-427a-9227-ee229a9caa9e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function divide: argument of numeric type cannot be first: In scope SELECT 2 / (1, 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT 2 / (1, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000704b5ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1003: DB::FunctionBinaryArithmetic::getFunctionForTupleAndNumberArithmetic(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000086b5119 5. /build/src/Functions/FunctionBinaryArithmetic.h:1622: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000877ad16 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:13:40.628884 [ 6986 ] {88c3218f-6ef4-427a-9227-ee229a9caa9e} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function divide: argument of numeric type cannot be first: In scope SELECT 2 / (1, 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000704b5ab 4. /build/src/Functions/FunctionBinaryArithmetic.h:1003: DB::FunctionBinaryArithmetic::getFunctionForTupleAndNumberArithmetic(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000086b5119 5. /build/src/Functions/FunctionBinaryArithmetic.h:1622: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000877ad16 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:13:42.594318 [ 5054 ] {94fa8035-bdf5-4037-af66-d0fddecfd31d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42374) (comment: 00950_test_double_delta_codec.sql) (in query: SELECT key, ref_valueU32, valueU32, ref_valueU32 - valueU32 as dU32 FROM codecTest WHERE dU32 != 0 LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:42.601354 [ 5054 ] {94fa8035-bdf5-4037-af66-d0fddecfd31d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:42.814126 [ 11749 ] {fd8786e0-9936-4f1d-aff3-2621c3ace6b8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44628) (comment: 00950_test_double_delta_codec.sql) (in query: DROP DATABASE IF EXISTS test_8dd0q6al ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:42.817043 [ 11749 ] {fd8786e0-9936-4f1d-aff3-2621c3ace6b8} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:42.874394 [ 6665 ] {9aa90da6-c801-480e-af84-db7d16c5ff64} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42470) (comment: 00990_hasToken.sh) (in query: SELECT hasTokenCaseInsensitive('hay hay hay hay hay hay hay hay hay NEEDLE hay hay hay hay hay hay hay hay hay', 'needle'), ' expecting ', 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:42.879234 [ 6665 ] {9aa90da6-c801-480e-af84-db7d16c5ff64} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:45.249172 [ 4191 ] {8f325bdf-9450-44d3-bcb6-a0ba197cd794} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42502) (comment: 00737_decimal_group_by.sql) (in query: SELECT A, B_str, toString(cc) FROM (SELECT A, toString(B) AS B_str, SUM(C) AS cc FROM decimal GROUP BY A, B_str);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:45.254608 [ 4191 ] {8f325bdf-9450-44d3-bcb6-a0ba197cd794} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:13:45.324413 [ 6665 ] {7e61bd29-2efc-4a66-bf0d-b09898a6d1a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36686) (comment: 01016_index_tuple_field_type.sql) (in query: SELECT * FROM tuple_01016 WHERE a < tuple(toDateTime('2019-01-01 00:00:00'), 0) format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:45.333973 [ 6665 ] {7e61bd29-2efc-4a66-bf0d-b09898a6d1a4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:45.517348 [ 6398 ] {a4e0a15d-0382-436c-8083-d4ab4ad0ae18} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36700) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:45.537161 [ 6398 ] {a4e0a15d-0382-436c-8083-d4ab4ad0ae18} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:46.678566 [ 3998 ] {6ea8dc94-671a-44c3-af1d-2b2750278d96} executeQuery: Code: 57. DB::Exception: Table test_93pm74xy.array_element_test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36740) (comment: 00036_array_element.sql) (in query: CREATE TABLE array_element_test (arr Array(String), id Int32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:46.681018 [ 3998 ] {6ea8dc94-671a-44c3-af1d-2b2750278d96} TCPHandler: Code: 57. DB::Exception: Table test_93pm74xy.array_element_test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:46.798430 [ 4191 ] {18279f67-be8a-45ce-9205-ecb79dce4653} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53612) (comment: 00036_array_element.sql) (in query: DROP DATABASE IF EXISTS test_93pm74xy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:46.825186 [ 4191 ] {18279f67-be8a-45ce-9205-ecb79dce4653} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:46.921245 [ 6665 ] {86f377ce-66ff-4ddb-8d2c-ee991b291b09} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53624) (comment: 00036_array_element.sql) (in query: DROP DATABASE IF EXISTS test_93pm74xy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:46.927462 [ 6665 ] {86f377ce-66ff-4ddb-8d2c-ee991b291b09} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:47.153334 [ 6665 ] {317cd9d0-647e-4db9-be30-114670a859a4} executeQuery: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36744) (comment: 02772_s3_crash.sql) (in query: SELECT * FROM s3(headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000000aa866eb 4. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000105c37c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000010590e87 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000102ae8be 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102afbce 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:47.155149 [ 6986 ] {d500c42c-e006-42ef-b074-c11bec1695bc} executeQuery: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got UInt8: In scope SELECT L1Norm(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT L1Norm(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b899eae 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:47.155339 [ 6665 ] {317cd9d0-647e-4db9-be30-114670a859a4} TCPHandler: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000000aa866eb 4. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000105c37c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000010590e87 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000102ae8be 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102afbce 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:47.162007 [ 6986 ] {d500c42c-e006-42ef-b074-c11bec1695bc} TCPHandler: Code: 43. DB::Exception: Argument 0 of function L1Norm should be tuple, got UInt8: In scope SELECT L1Norm(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b899eae 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:47.257074 [ 6665 ] {e05abbe0-0ebd-4b9a-b881-29fd82560707} executeQuery: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36744) (comment: 02772_s3_crash.sql) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000000aa866eb 4. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000105c37c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000010590e87 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000102d2ca6 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102b100e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102d29c4 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:47.263550 [ 6665 ] {e05abbe0-0ebd-4b9a-b881-29fd82560707} TCPHandler: Code: 42. DB::Exception: Storage S3 requires 1 to 7 arguments. All supported signatures: - url - url, NOSIGN - url, format - url, NOSIGN, format - url, format, structure - url, NOSIGN, format, structure - url, format, structure, compression_method - url, NOSIGN, format, structure, compression_method - url, access_key_id, secret_access_key - url, access_key_id, secret_access_key, session_token - url, access_key_id, secret_access_key, format - url, access_key_id, secret_access_key, session_token, format - url, access_key_id, secret_access_key, format, structure - url, access_key_id, secret_access_key, session_token, format, structure - url, access_key_id, secret_access_key, format, structure, compression_method - url, access_key_id, secret_access_key, session_token, format, structure, compression_method All signatures supports 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000000aa866eb 4. /build/src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000105c37c8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x0000000010590e87 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArgumentsImpl(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000102d2ca6 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TableFunctionObjectStorage::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102b100e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ITableFunctionCluster>::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000102d29c4 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:13:47.324680 [ 6986 ] {513dd3f0-f32f-4216-b155-0f7821493623} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and String of arguments of function divide: In scope SELECT (1, 1) / toString(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT (1, 1) / toString(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000877b365 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:47.339713 [ 6986 ] {513dd3f0-f32f-4216-b155-0f7821493623} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and String of arguments of function divide: In scope SELECT (1, 1) / toString(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000877b365 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000786f7fb 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:47.566954 [ 6986 ] {c1e99321-d9e3-4323-a33f-a8219f4703fc} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function negate: While executing function tupleNegate for tuple element 1: In scope SELECT -(1, toString(1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT -(1, toString(1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000aa80b1d 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Functions/vectorFunctions.cpp:195: DB::FunctionTupleNegate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8805b3 10. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 11. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 12. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 13. /build/src/Functions/FunctionUnaryArithmetic.h:272: DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000aa808a9 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 15. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 16. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 17. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 28. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 2025.06.25 16:13:47.569225 [ 6986 ] {c1e99321-d9e3-4323-a33f-a8219f4703fc} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function negate: While executing function tupleNegate for tuple element 1: In scope SELECT -(1, toString(1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000aa80b1d 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Functions/vectorFunctions.cpp:195: DB::FunctionTupleNegate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8805b3 10. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 11. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 12. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 13. /build/src/Functions/FunctionUnaryArithmetic.h:272: DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000aa808a9 14. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 15. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 16. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 17. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 22. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 25. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 28. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 29. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 31. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 2025.06.25 16:13:47.691414 [ 3998 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:47.822927 [ 6986 ] {5f58df6a-bc6d-40ed-b587-5c6716dedf83} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2), toDecimal32(2, 4)). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2), toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a4507 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:47.826935 [ 6986 ] {5f58df6a-bc6d-40ed-b587-5c6716dedf83} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2), toDecimal32(2, 4)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a4507 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:48.065726 [ 6986 ] {6d2d5feb-4293-4112-9419-3e85cb57bc42} executeQuery: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function cosineDistance, got Tuple(UInt8, UInt8) and Tuple(UInt8, UInt8, UInt8): In scope SELECT cosineDistance((1, 2), (2, 3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT cosineDistance((1, 2), (2, 3, 4));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::(anonymous namespace)::checkAndGetTuplesSize(std::shared_ptr const&, std::shared_ptr const&, String const&) @ 0x000000000b86b56d 5. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionCosineDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8b737b 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:48.067271 [ 6986 ] {6d2d5feb-4293-4112-9419-3e85cb57bc42} TCPHandler: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function cosineDistance, got Tuple(UInt8, UInt8) and Tuple(UInt8, UInt8, UInt8): In scope SELECT cosineDistance((1, 2), (2, 3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::(anonymous namespace)::checkAndGetTuplesSize(std::shared_ptr const&, std::shared_ptr const&, String const&) @ 0x000000000b86b56d 5. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionCosineDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b8b737b 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:13:48.094890 [ 4191 ] {58b685bc-49aa-4911-8113-9c0fd78753fb} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: create table test1601_detach_permanently_atomic.test_name_reuse (number UInt64) engine=MergeTree order by tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:48.101087 [ 4191 ] {58b685bc-49aa-4911-8113-9c0fd78753fb} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:48.205225 [ 6986 ] {694b6e1c-ef92-450e-82c6-660f2d814cc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm((1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: -- TODO: what's the expected value of () + ()? Currently it returns 0. -- SELECT tuple() + tuple(); -- { serverError NUMBER_OF_ARGUMENTS_DOESNT_MATCH } SELECT LpNorm((1, 2, 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.207921 [ 6986 ] {694b6e1c-ef92-450e-82c6-660f2d814cc5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 1, should be 2: In scope SELECT LpNorm((1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.213396 [ 6155 ] {966ebc21-dbb3-4d59-8ab6-4395ef9031c8} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42492) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIf(n, last > 50) FILTER(WHERE last>50) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.216762 [ 6155 ] {966ebc21-dbb3-4d59-8ab6-4395ef9031c8} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.272279 [ 4191 ] {8d6e5e4d-7a51-405e-91aa-0e43f66f2695} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.274473 [ 4191 ] {8d6e5e4d-7a51-405e-91aa-0e43f66f2695} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.274846 [ 6986 ] {525235b3-3573-4f56-944a-6dad7a49ec9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(1, 2, -1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT max2(1, 2, -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.276235 [ 6986 ] {525235b3-3573-4f56-944a-6dad7a49ec9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(1, 2, -1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.399865 [ 6986 ] {33b3b30c-a4c0-4648-9622-ff31a1d4908d} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), materialize(4.));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a446a 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.402827 [ 6986 ] {33b3b30c-a4c0-4648-9622-ff31a1d4908d} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a446a 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 12. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 15. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 16. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 17. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 18. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 19. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 20. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:13:48.411007 [ 4191 ] {25ff4942-d1d2-461f-b98f-3ae6dcdf5de1} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.414340 [ 4191 ] {25ff4942-d1d2-461f-b98f-3ae6dcdf5de1} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.482643 [ 6155 ] {8662ac1e-664e-4aa9-a6f9-9a84cfca4848} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42492) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.484013 [ 6155 ] {8662ac1e-664e-4aa9-a6f9-9a84cfca4848} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.491441 [ 4191 ] {3893f510-6080-4c5b-a8c7-fa0ca802e96f} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: drop table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.492756 [ 4191 ] {3893f510-6080-4c5b-a8c7-fa0ca802e96f} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:48.527146 [ 6155 ] {1c61a9c4-3639-44c1-92fc-c6dce1e38775} executeQuery: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42492) (comment: 02025_nested_func_for_if_combinator.sql) (in query: SELECT uniqCombinedIfMergeIfIf(n, last > 5, 1) FROM (SELECT uniqCombinedIfState(number, number % 2) AS n, max(number) AS last FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.528836 [ 6155 ] {1c61a9c4-3639-44c1-92fc-c6dce1e38775} TCPHandler: Code: 184. DB::Exception: Nested identical combinator 'If' is not supported. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:241: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bd081 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:13:48.589513 [ 6986 ] {09f56042-9010-46e3-92b4-7b91ad8515b3} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpDistance(tuple(*, 1), tuple(2, *), * + 1.) FROM numbers(3, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a446a 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::FunctionLDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae3af 12. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ada57 13. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 14. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 19. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 21. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 23. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 24. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 25. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 26. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 27. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:13:48.596410 [ 6986 ] {09f56042-9010-46e3-92b4-7b91ad8515b3} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a446a 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::FunctionLDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ae3af 12. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8ada57 13. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 14. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 19. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 21. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 23. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 24. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 25. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 26. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 27. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:13:48.922743 [ 4191 ] {9ebd4715-195c-46c0-927d-bb466642acf2} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: RENAME TABLE test1601_detach_permanently_atomic.test_name_rename_attempt TO test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe982 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:48.924314 [ 4191 ] {9ebd4715-195c-46c0-927d-bb466642acf2} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe982 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:48.998115 [ 4191 ] {983b86c8-1232-4127-85f5-861c04a4f815} executeQuery: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: EXCHANGE TABLES test1601_detach_permanently_atomic.test_name_rename_attempt AND test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbea74 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:49.015157 [ 4191 ] {983b86c8-1232-4127-85f5-861c04a4f815} TCPHandler: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbea74 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:49.333465 [ 4191 ] {f2d5af6f-6794-48e9-b093-8549e8b4c794} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.25 16:13:49.542746 [ 4191 ] {f2d5af6f-6794-48e9-b093-8549e8b4c794} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: ATTACH TABLE test1601_detach_permanently_atomic.test_name_reuse UUID '00000000-0000-0000-0000-000000000001' (`number` UInt64 ) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192 ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000010dad586 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155e1e7 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:49.545565 [ 4191 ] {f2d5af6f-6794-48e9-b093-8549e8b4c794} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000010dad586 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155e1e7 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:49.677426 [ 6986 ] {47103894-2703-49fe-9e52-02d0dcd4df43} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((3, 1, 4), 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((3, 1, 4), 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.680236 [ 6986 ] {47103894-2703-49fe-9e52-02d0dcd4df43} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((3, 1, 4), 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.734626 [ 6986 ] {9a9b0904-2fe4-4ecb-a295-3a63e43e40e2} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.5). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), 0.5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.740745 [ 6986 ] {9a9b0904-2fe4-4ecb-a295-3a63e43e40e2} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.5). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.779801 [ 6986 ] {5be311cf-3616-4933-8e25-a2bcbad64b6c} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), inf). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.781663 [ 6986 ] {5be311cf-3616-4933-8e25-a2bcbad64b6c} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), inf). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.821621 [ 6986 ] {c522cf56-771b-4463-9d4c-9a61fe7605e8} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), -1.). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), -1.);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.823868 [ 6986 ] {c522cf56-771b-4463-9d4c-9a61fe7605e8} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), -1.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.857674 [ 6986 ] {1baad095-eedd-42c7-a087-b7305a9aaada} executeQuery: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2, 3), -1). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a4507 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.860150 [ 6986 ] {1baad095-eedd-42c7-a087-b7305a9aaada} TCPHandler: Code: 44. DB::Exception: Second argument for function LpNorm must be either constant Float64 or constant UInt: In scope SELECT LpNorm((1, 2, 3), -1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a4507 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.919267 [ 6986 ] {46c11b93-f422-4157-9898-82523ae75a04} executeQuery: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42322) (comment: 02011_tuple_vector_functions.sql) (in query: SELECT LpNorm((1, 2, 3), 0.);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:49.921179 [ 6986 ] {46c11b93-f422-4157-9898-82523ae75a04} TCPHandler: Code: 69. DB::Exception: Second argument for function LpNorm must be not less than one and not be an infinity: In scope SELECT LpNorm((1, 2, 3), 0.). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/vectorFunctions.cpp:0: DB::FunctionLNorm::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a43cd 5. /build/src/Functions/vectorFunctions.cpp:1443: DB::TupleOrArrayFunction::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b8a22b7 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:13:50.000219 [ 4191 ] {02831118-dde5-4711-b186-88dd7b3196a6} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:50.001834 [ 4191 ] {02831118-dde5-4711-b186-88dd7b3196a6} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:50.599705 [ 4191 ] {a6a7732f-64bd-4b2b-9aa2-9fa89ea80a36} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:50.601040 [ 4191 ] {a6a7732f-64bd-4b2b-9aa2-9fa89ea80a36} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:51.144457 [ 4191 ] {ce473a00-0fac-4372-bdd7-e81e0535b4dd} Context: Server has databases (for example `test1601_detach_permanently_ordinary`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.06.25 16:13:51.334398 [ 5056 ] {97d055ff-1d59-4f7a-88a3-e129e9a084f6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36828) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:51.336893 [ 5056 ] {97d055ff-1d59-4f7a-88a3-e129e9a084f6} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:51.765584 [ 4191 ] {373e0533-2745-4b7d-b22c-cc3f19458846} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: create table test1601_detach_permanently_ordinary.test_name_reuse (number UInt64) engine=MergeTree order by tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:51.771142 [ 4191 ] {373e0533-2745-4b7d-b22c-cc3f19458846} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:51.881766 [ 4191 ] {d85f2230-011c-40c5-abc1-9ae2a52f1404} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:51.886963 [ 4191 ] {d85f2230-011c-40c5-abc1-9ae2a52f1404} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:52.053332 [ 4191 ] {82330d80-bf5c-450d-8cbe-a6a4f67f1111} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:52.055057 [ 4191 ] {82330d80-bf5c-450d-8cbe-a6a4f67f1111} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:52.102069 [ 11749 ] {c70f008d-803e-4c54-bfb6-24d608bd9f00} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36818) (comment: 00934_is_valid_utf8.sql) (in query: select 1 = isValidUTF8('\x7F') from system.numbers limit 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:52.116221 [ 11749 ] {c70f008d-803e-4c54-bfb6-24d608bd9f00} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:52.237869 [ 4191 ] {7b367979-0068-4816-bb79-b4b717fef4e7} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: drop table test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:52.250265 [ 4191 ] {7b367979-0068-4816-bb79-b4b717fef4e7} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:52.537625 [ 4191 ] {65f4160d-dc30-40f8-8948-d07e90a2cced} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: RENAME TABLE test1601_detach_permanently_ordinary.test_name_rename_attempt TO test1601_detach_permanently_ordinary.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010db1104 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 8. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:52.542617 [ 4191 ] {65f4160d-dc30-40f8-8948-d07e90a2cced} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_ordinary`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010db1104 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 8. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:52.857150 [ 4191 ] {a5a253dd-1af2-454d-b892-b38f07c952ad} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.25 16:13:53.408780 [ 4191 ] {aaf310e3-fb91-4a14-8d83-25ad561514ff} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:53.411278 [ 4191 ] {aaf310e3-fb91-4a14-8d83-25ad561514ff} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:54.608388 [ 4191 ] {d588c794-3fde-4708-bc5d-72c6abcf68a9} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_ordinary.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:54.610350 [ 4191 ] {d588c794-3fde-4708-bc5d-72c6abcf68a9} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_ordinary.test_name_reuse does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:55.224113 [ 4191 ] {aa22e873-c46c-4b14-a65d-2fc4e3e9902d} executeQuery: Code: 219. DB::Exception: Cannot drop: filesystem error: in remove: Directory not empty ["/var/lib/clickhouse/data/test1601_detach_permanently_ordinary/"]. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DROP DATABASE test1601_detach_permanently_ordinary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x00000000099792cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x0000000010db3a0f 5. /build/src/Interpreters/DatabaseCatalog.cpp:613: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179268 6. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:55.232624 [ 4191 ] {aa22e873-c46c-4b14-a65d-2fc4e3e9902d} TCPHandler: Code: 219. DB::Exception: Cannot drop: filesystem error: in remove: Directory not empty ["/var/lib/clickhouse/data/test1601_detach_permanently_ordinary/"]. Probably database contain some detached tables or metadata leftovers from Ordinary engine. If you want to remove all data anyway, try to attach database back and drop it again with enabled force_remove_data_recursively_on_drop setting. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x00000000099792cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::drop(std::shared_ptr) @ 0x0000000010db3a0f 5. /build/src/Interpreters/DatabaseCatalog.cpp:613: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179268 6. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:55.524698 [ 4191 ] {a10296a5-d532-4837-b8f0-49c6a1d4e608} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36758) (comment: 01601_detach_permanently.sql) (in query: DROP DATABASE test1601_detach_permanently_ordinary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:55.527253 [ 4191 ] {a10296a5-d532-4837-b8f0-49c6a1d4e608} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:56.515196 [ 6665 ] {a174f3f6-5f0e-4cc8-8da9-a9a9054facf4} executeQuery: Code: 57. DB::Exception: Table test_tqukfp7o.r already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57820) (comment: 01410_full_join_and_null_predicates.sql) (in query: CREATE TABLE r (`ruid` Nullable(Int16), `name` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 46520, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 29, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 494050580, compact_parts_max_granules_to_buffer = 110, compact_parts_merge_max_bytes_to_prefetch_part = 15325403, merge_max_block_size = 6616, old_parts_lifetime = 63., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 60, min_merge_bytes_to_use_direct_io = 5095947330, index_granularity_bytes = 12655958, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 81778, primary_key_compress_block_size = 18160 AS SELECT * FROM VALUES((1231, 'John'), (1232, 'Johny'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:56.523816 [ 6665 ] {a174f3f6-5f0e-4cc8-8da9-a9a9054facf4} TCPHandler: Code: 57. DB::Exception: Table test_tqukfp7o.r already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:13:56.652086 [ 8172 ] {26c59204-2e02-4cfc-af4e-cec8853bf09f} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: create table test1601_detach_permanently_atomic.test_name_reuse (number UInt64) engine=MergeTree order by tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:56.653689 [ 8172 ] {26c59204-2e02-4cfc-af4e-cec8853bf09f} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000010db0742 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155c83c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:56.654093 [ 6836 ] {99ae2001-dc71-4fac-afaf-c6178e848a75} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37326) (comment: 01410_full_join_and_null_predicates.sql) (in query: DROP DATABASE IF EXISTS test_tqukfp7o ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:13:56.655720 [ 6836 ] {99ae2001-dc71-4fac-afaf-c6178e848a75} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:56.695966 [ 3280 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:13:56.708713 [ 2952 ] {75d688a4-811d-4fa5-bd13-443d87fc1230} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57832) (comment: 03032_redundant_equals.sql) (in query: SELECT * FROM test_table WHERE k < 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:56.711111 [ 2952 ] {75d688a4-811d-4fa5-bd13-443d87fc1230} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:56.819903 [ 8172 ] {1afb5021-5d5b-410d-af83-051ff2bcf9ff} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse PERMANENTLY;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:56.824615 [ 8172 ] {1afb5021-5d5b-410d-af83-051ff2bcf9ff} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:56.919966 [ 8172 ] {b9916454-3f69-48c1-b5e9-ce34446ac87b} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: DETACH table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:56.929492 [ 8172 ] {b9916454-3f69-48c1-b5e9-ce34446ac87b} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:57.118661 [ 8172 ] {bc317bcd-6a6f-40a7-816e-52ab06a0a1ac} executeQuery: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: drop table test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:57.119511 [ 8172 ] {bc317bcd-6a6f-40a7-816e-52ab06a0a1ac} TCPHandler: Code: 60. DB::Exception: Table test1601_detach_permanently_atomic.test_name_reuse does not exist. Maybe you meant test1601_detach_permanently_ordinary.test_name_reuse?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:57.384580 [ 8172 ] {a07ecfca-c59c-45e7-8802-eb3c321da231} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: RENAME TABLE test1601_detach_permanently_atomic.test_name_rename_attempt TO test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe982 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:57.387066 [ 8172 ] {a07ecfca-c59c-45e7-8802-eb3c321da231} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exists (detached permanently). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000010db0988 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe982 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:57.508792 [ 8172 ] {d05b4d60-9485-40e0-99fc-7bbdc5e30285} executeQuery: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: EXCHANGE TABLES test1601_detach_permanently_atomic.test_name_rename_attempt AND test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbea74 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:57.512240 [ 8172 ] {d05b4d60-9485-40e0-99fc-7bbdc5e30285} TCPHandler: Code: 60. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbea74 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:57.791580 [ 8172 ] {d0a8fa55-c463-4f61-bb5d-e2e71ae0e6a2} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE test_name_reuse; to attach existing table or CREATE TABLE test_name_reuse
; to create new table or ATTACH TABLE test_name_reuse FROM '/path/to/data/'
; to create new table and attach data. 2025.06.25 16:13:57.884218 [ 8172 ] {d0a8fa55-c463-4f61-bb5d-e2e71ae0e6a2} executeQuery: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: ATTACH TABLE test1601_detach_permanently_atomic.test_name_reuse UUID '00000000-0000-0000-0000-000000000001' (`number` UInt64 ) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8192 ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000010dad586 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155e1e7 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:57.890441 [ 8172 ] {d0a8fa55-c463-4f61-bb5d-e2e71ae0e6a2} TCPHandler: Code: 57. DB::Exception: Table `test1601_detach_permanently_atomic`.`test_name_reuse` already exist (detached or detached permanently). To attach it back you need to use short ATTACH syntax (ATTACH TABLE `test1601_detach_permanently_atomic`.`test_name_reuse`;). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000010dad586 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155e1e7 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:58.145579 [ 8172 ] {ed9938e5-ad03-4ae9-8a6c-8ba2958eca74} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57850) (comment: 01601_detach_permanently.sql) (in query: ATTACH TABLE test1601_detach_permanently_atomic.test_name_reuse;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:58.148492 [ 8172 ] {ed9938e5-ad03-4ae9-8a6c-8ba2958eca74} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:58.907893 [ 5056 ] {38c5b64b-05e1-4f33-bf44-863f5607d6db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36832) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SELECT ProfileEvents['CachedReadBufferReadFromCacheHits'] > 0 as remote_fs_cache_hit, ProfileEvents['CachedReadBufferReadFromCacheMisses'] > 0 as remote_fs_cache_miss, ProfileEvents['CachedReadBufferReadFromSourceBytes'] > 0 as remote_fs_read, ProfileEvents['CachedReadBufferReadFromCacheBytes'] > 0 as remote_fs_cache_read, ProfileEvents['CachedReadBufferCacheWriteBytes'] > 0 as remote_fs_read_and_download FROM system.query_log WHERE query_id='' AND type = 'QueryFinish' AND current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:13:58.918050 [ 5056 ] {38c5b64b-05e1-4f33-bf44-863f5607d6db} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:13:59.112632 [ 6836 ] {85ffe130-ab1f-4d53-89ee-3808f43d5486} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57950) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value LIMIT 10 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:59.117025 [ 6665 ] {f5ae2c72-4e3c-4ca2-80a4-7dc6115e257f} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT tupleIntDiv((15, 10, 5), (0, 0, 0)). (ILLEGAL_DIVISION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57934) (comment: 03033_tupleIntXYZ_and_tupleModulo.sql) (in query: SELECT tupleIntDiv((15, 10, 5), (0, 0, 0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)0>(char8_t const*, char8_t const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000959936a 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009711a79 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x0000000009710a10 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x000000000970ff87 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:201: DB::FunctionTupleOperator::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b87b55c 16. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 17. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 19. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 20. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 21. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 23. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 24. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 27. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 2025.06.25 16:13:59.126645 [ 6836 ] {85ffe130-ab1f-4d53-89ee-3808f43d5486} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:13:59.132567 [ 6665 ] {f5ae2c72-4e3c-4ca2-80a4-7dc6115e257f} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT tupleIntDiv((15, 10, 5), (0, 0, 0)). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: void DB::impl_::BinaryOperation, char8_t>::process<(DB::impl_::OpCase)0>(char8_t const*, char8_t const*, char8_t*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000959936a 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009711a79 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x0000000009710a10 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x000000000970ff87 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:201: DB::FunctionTupleOperator::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b87b55c 16. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 17. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 19. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 20. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 21. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 23. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 24. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 27. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 2025.06.25 16:13:59.241642 [ 8172 ] {2d92f727-0bab-47e9-83f1-8c62d76b3d05} executeQuery: Code: 46. DB::Exception: Function with name 'plu' does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57954) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT plu(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:59.258700 [ 8172 ] {2d92f727-0bab-47e9-83f1-8c62d76b3d05} TCPHandler: Code: 46. DB::Exception: Function with name 'plu' does not exist. In scope SELECT plu(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['plus']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:59.278595 [ 4197 ] {219509bb-ef6c-448f-9fab-a05fe6f59722} executeQuery: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57958) (comment: 02226_filesystem_cache_profile_events.sh) (in query: DROP TABLE test_02226), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:59.297277 [ 4197 ] {219509bb-ef6c-448f-9fab-a05fe6f59722} TCPHandler: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:13:59.417501 [ 6665 ] {f11caff2-9efa-49cf-90a6-213bfad23d76} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57934) (comment: 03033_tupleIntXYZ_and_tupleModulo.sql) (in query: SELECT tupleIntDiv((15, 10, 5), (5.5, 5.5, 5.5));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:59.419418 [ 6665 ] {f11caff2-9efa-49cf-90a6-213bfad23d76} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:13:59.461788 [ 4197 ] {e2df79e6-4f8b-41cd-9b37-07ba62466735} executeQuery: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57974) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SET max_memory_usage='20G';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:59.471201 [ 4197 ] {e2df79e6-4f8b-41cd-9b37-07ba62466735} TCPHandler: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:13:59.580617 [ 6665 ] {31420472-0c44-46d2-8d88-c55614e21439} executeQuery: Code: 46. DB::Exception: Function with name 'uniqExac' does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57990) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:59.583982 [ 6665 ] {31420472-0c44-46d2-8d88-c55614e21439} TCPHandler: Code: 46. DB::Exception: Function with name 'uniqExac' does not exist. In scope SELECT uniqExac(1, 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['uniqExact']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:59.628757 [ 8172 ] {cf12c535-214e-4eba-81ee-55568e1fc889} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57994) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:13:59.649096 [ 8172 ] {cf12c535-214e-4eba-81ee-55568e1fc889} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:00.196672 [ 6155 ] {5b24feed-da35-49f2-a8d6-f82bb538f152} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58030) (comment: 03142_skip_ANSI_in_UTF8_compute_width.sql) (in query: SELECT format('\x1b[38;2;{0};{1};{2}mâ–ˆ\x1b[0m', 255, 128, 128) AS x FORMAT Pretty;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:00.219814 [ 6155 ] {5b24feed-da35-49f2-a8d6-f82bb538f152} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:00.590181 [ 6155 ] {bd7e2fa0-bec5-4e19-a25f-b469e5fced5d} executeQuery: Code: 46. DB::Exception: Function with name 'test_user_defined_function_test_hz9e78qeA' does not exist. In scope SELECT test_user_defined_function_test_hz9e78qeA(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_hz9e78qe']. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58046) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT test_user_defined_function_test_hz9e78qeA(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:00.597575 [ 6155 ] {bd7e2fa0-bec5-4e19-a25f-b469e5fced5d} TCPHandler: Code: 46. DB::Exception: Function with name 'test_user_defined_function_test_hz9e78qeA' does not exist. In scope SELECT test_user_defined_function_test_hz9e78qeA(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['test_user_defined_function_test_hz9e78qe']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:00.800101 [ 4027 ] {5fdb7290-4bc9-4615-8c06-5648fc637773} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57904) (comment: 00173_compare_date_time_with_constant_string.sql) (in query: SELECT '2015-02-03' = materialize(toDate('2015-02-04'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:00.803506 [ 4027 ] {5fdb7290-4bc9-4615-8c06-5648fc637773} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:01.439631 [ 5054 ] {f36e0106-23a5-495c-ada6-c7e941869444} executeQuery: Code: 46. DB::Exception: Function with name 'lambda_functio' does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58092) (comment: 02477_analyzer_function_hints.sh) (in query: WITH (x -> x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:01.449288 [ 5054 ] {f36e0106-23a5-495c-ada6-c7e941869444} TCPHandler: Code: 46. DB::Exception: Function with name 'lambda_functio' does not exist. In scope WITH x -> (x + 1) AS lambda_function SELECT lambda_functio(1) SETTINGS enable_analyzer = 1. Maybe you meant: ['lambda_function']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053349 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:02.216408 [ 5054 ] {7db929ed-3d58-4c9e-81b7-84db8357d124} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58100) (comment: 02477_analyzer_function_hints.sh) (in query: SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011052bb3 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:02.229232 [ 5054 ] {7db929ed-3d58-4c9e-81b7-84db8357d124} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'row_numbe' does not exist. In scope SELECT row_numbe() OVER (PARTITION BY 1) SETTINGS enable_analyzer = 1. Maybe you meant: ['row_number']. (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011052bb3 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:03.497744 [ 4197 ] {1b886a0c-9632-43b7-bec9-1f5fa83b5226} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58120) (comment: 02695_storage_join_insert_select_deadlock.sql) (in query: INSERT INTO test_table_join SELECT * from test_table_join;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:03.506508 [ 4197 ] {1b886a0c-9632-43b7-bec9-1f5fa83b5226} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:04.349223 [ 6155 ] {9ab7d468-3ad7-4690-bc62-1b3082af44c9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58154) (comment: 02480_analyzer_alias_nullptr.sql) (in query: SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:04.360913 [ 6155 ] {9ab7d468-3ad7-4690-bc62-1b3082af44c9} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:04.972243 [ 4197 ] {e077ec0f-263e-4f08-af85-ea4006f7b078} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:14:05.004056 [ 4197 ] {e077ec0f-263e-4f08-af85-ea4006f7b078} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39884) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: CREATE TABLE mutations_r1 (`x` UInt32, `y` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00652_replicated_mutations_default_database_zookeeper_test_11/mutations', 'r1') ORDER BY x SETTINGS index_granularity = 1479, min_bytes_for_wide_part = 588490860, 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 = 436505342, compact_parts_max_bytes_to_buffer = 512287701, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 1613233, merge_max_block_size = 14205, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9405398071, index_granularity_bytes = 2316989, concurrent_part_removal_threshold = 34, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88902, primary_key_compress_block_size = 45895), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:05.031059 [ 4197 ] {e077ec0f-263e-4f08-af85-ea4006f7b078} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:05.584889 [ 5054 ] {252cf541-8269-449a-9d56-aa83bbe28398} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_r1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39914) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: SELECT * FROM mutations_r1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:05.605345 [ 5054 ] {252cf541-8269-449a-9d56-aa83bbe28398} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_r1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:06.063650 [ 6398 ] {992a0af5-b5ac-4dca-aca5-db61f50578d0} executeQuery: Code: 60. DB::Exception: Table test_11.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39918) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE mutations_r1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:06.116892 [ 6398 ] {992a0af5-b5ac-4dca-aca5-db61f50578d0} TCPHandler: Code: 60. DB::Exception: Table test_11.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:06.696675 [ 6155 ] {f116397b-cb98-4042-8ab2-6388800817ac} executeQuery: Code: 60. DB::Exception: Table test_11.for_subquery does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39938) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE for_subquery), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:06.716037 [ 6155 ] {f116397b-cb98-4042-8ab2-6388800817ac} TCPHandler: Code: 60. DB::Exception: Table test_11.for_subquery does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:07.678066 [ 3632 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8615fb30-d08c-48c1-a41a-01099e1320ba::202506_1_35_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:08.240187 [ 6398 ] {1cad5b69-4a17-4d94-8dd5-a8f3ec97e2a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39940) (comment: 00048_a_stored_aggregates_merge.sql) (in query: SELECT uniqMerge(Uniq) FROM stored_aggregates;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:08.247552 [ 6398 ] {1cad5b69-4a17-4d94-8dd5-a8f3ec97e2a4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:09.345142 [ 11749 ] {8ec2894e-59a4-491b-873a-86888e7ce8c1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40018) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:09.351717 [ 11749 ] {8ec2894e-59a4-491b-873a-86888e7ce8c1} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:09.567726 [ 6155 ] {ad8bb941-1b69-4689-8b4a-c88adff218bb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Education' in scope SELECT FirstName, LastName, Education FROM (SELECT FirstName, LastName, Occupation FROM Customers LIMIT 3). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39958) (comment: 02366_kql_tabular.sql) (in query: Customers| project FirstName,LastName,Occupation | take 3 | project FirstName,LastName,Education;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:09.573017 [ 6155 ] {ad8bb941-1b69-4689-8b4a-c88adff218bb} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Education' in scope SELECT FirstName, LastName, Education FROM (SELECT FirstName, LastName, Occupation FROM Customers LIMIT 3). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:10.026484 [ 11749 ] {33e3f33c-aa25-4693-bee8-71e9b8d4b325} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40040) (comment: 01624_soft_constraints.sh) (in query: SELECT count() FROM hypothesis_test_test WHERE c < a FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:10.117028 [ 11749 ] {33e3f33c-aa25-4693-bee8-71e9b8d4b325} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:10.195109 [ 2956 ] {08ed7478-ebda-4899-bb75-75e8c0bffe53} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58018) (comment: 02998_pretty_format_print_readable_number_on_single_value.sql) (in query: SELECT '2024-02-29 00:00:00'::DateTime FORMAT PrettyMonoBlock;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:10.209969 [ 2956 ] {08ed7478-ebda-4899-bb75-75e8c0bffe53} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:13.517705 [ 6986 ] {1d04056c-89c4-4058-8463-4a8bc7a2a9e8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35720) (comment: 02156_storage_merge_prewhere_not_ready_set_bug.sql) (in query: DROP DATABASE IF EXISTS test_1x50qb72 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:14:13.527522 [ 6986 ] {1d04056c-89c4-4058-8463-4a8bc7a2a9e8} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:13.650156 [ 6155 ] {7cce045d-b40c-4001-9fdb-76f45374effc} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 55 ('by'): by LastName;. Max query size exceeded: 'by'. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39958) (comment: 02366_kql_tabular.sql) (in query: Customers | where Education contains 'degree' | order b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007032a8d 3. /build/src/Parsers/Kusto/parseKQLQuery.cpp:454: DB::parseKQLQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001364c58c 4. /build/src/Parsers/Kusto/parseKQLQuery.cpp:466: DB::parseKQLQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001364c61e 5. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d0da 6. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:13.652068 [ 6155 ] {7cce045d-b40c-4001-9fdb-76f45374effc} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 55 ('by'): by LastName;. Max query size exceeded: 'by'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007032a8d 3. /build/src/Parsers/Kusto/parseKQLQuery.cpp:454: DB::parseKQLQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001364c58c 4. /build/src/Parsers/Kusto/parseKQLQuery.cpp:466: DB::parseKQLQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001364c61e 5. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d0da 6. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 9. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:13.825133 [ 5174 ] {c4dbb57c-4fec-41db-9b46-7790d831f75f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40102) (comment: 02562_regexp_extract.sql) (in query: select regexpExtract('100-200', '([a-z])', null);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:13.830986 [ 5174 ] {c4dbb57c-4fec-41db-9b46-7790d831f75f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:16.555469 [ 6986 ] {bbb12daa-5121-403a-94be-dfa4387acc08} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34058) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:16.561241 [ 6986 ] {bbb12daa-5121-403a-94be-dfa4387acc08} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:17.753264 [ 4191 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:18.569377 [ 6665 ] {4c0b9618-f246-4627-be7c-3235cb777f0a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34112) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE IF EXISTS 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:18.574504 [ 6665 ] {4c0b9618-f246-4627-be7c-3235cb777f0a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:19.262498 [ 2952 ] {02cc1b4a-34a8-4f97-bafe-dc2ca457d2f6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34134) (comment: 01902_table_function_merge_db_params.sql) (in query: DROP DATABASE IF EXISTS 01902_db_params;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:19.280071 [ 2952 ] {02cc1b4a-34a8-4f97-bafe-dc2ca457d2f6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:21.056483 [ 2952 ] {a9d275ff-a0b9-4f82-a352-abb7d74d0df4} executeQuery: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34154) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge() ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:21.059262 [ 2952 ] {a9d275ff-a0b9-4f82-a352-abb7d74d0df4} TCPHandler: Code: 42. DB::Exception: Table function 'merge' requires from 1 to 2 parameters: merge(['db_name',] 'tables_regexp'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:120: DB::(anonymous namespace)::TableFunctionMerge::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001026018d 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103bd4b 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:21.131186 [ 2952 ] {c3053859-8ab9-4e4a-a74b-606f3590007d} executeQuery: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_yfuevlzv`, or there are no tables in database matches `test_yfuevlzv`, which fit tables expression: ^t. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34154) (comment: 01902_table_function_merge_db_params.sql) (in query: SELECT _database, _table, n FROM merge('^t') ORDER BY _database, _table, n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:21.139971 [ 2952 ] {c3053859-8ab9-4e4a-a74b-606f3590007d} TCPHandler: Code: 36. DB::Exception: Error while executing table function merge. Either there is no database, which matches regular expression `test_yfuevlzv`, or there are no tables in database matches `test_yfuevlzv`, which fit tables expression: ^t. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String const&) @ 0x000000001026246b 4. /build/src/TableFunctions/TableFunctionMerge.cpp:31: DB::(anonymous namespace)::throwNoTablesMatchRegexp(String const&, String const&) @ 0x0000000010260f8c 5. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getSourceDatabasesAndTables(std::shared_ptr) const @ 0x0000000010260e83 6. /build/src/TableFunctions/TableFunctionMerge.cpp:0: DB::(anonymous namespace)::TableFunctionMerge::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000010260299 7. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::TableFunctionMerge::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102607d6 8. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 9. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:22.203178 [ 2952 ] {21a2c049-e3e5-45bf-a048-1a371605e6cb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34180) (comment: 01667_aes_args_check.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087b98b8 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:22.207376 [ 2952 ] {21a2c049-e3e5-45bf-a048-1a371605e6cb} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x00000000087b98b8 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:23.561204 [ 6379 ] {6d3bf00f-133f-4314-8824-d70bdd686dcc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36782) (comment: 02271_replace_partition_many_tables.sql) (in query: SELECT * FROM replace_partition_source;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:23.563942 [ 6379 ] {6d3bf00f-133f-4314-8824-d70bdd686dcc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:24.154738 [ 6836 ] {a7808a49-b702-4c13-a793-2ac8fb545ee9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34232) (comment: 00919_sum_aggregate_states_constants.sql) (in query: SELECT finalizeAggregation((SELECT sumState(number) FROM numbers(10)) + (SELECT sumState(number) FROM numbers(10)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:24.169888 [ 6836 ] {a7808a49-b702-4c13-a793-2ac8fb545ee9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:14:24.496835 [ 3636 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d51fb3e-a590-4ced-8b53-2573812c4bf0::202506_1_26_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:25.007693 [ 6986 ] {f609a0bc-4a9d-4871-8c67-d045c72f4f0f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35648) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value LIMIT 10 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:25.011082 [ 6986 ] {f609a0bc-4a9d-4871-8c67-d045c72f4f0f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:25.241367 [ 6665 ] {2644487e-9d28-4b3b-bebe-5365e5ac5da4} executeQuery: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35664) (comment: 02226_filesystem_cache_profile_events.sh) (in query: DROP TABLE test_02226), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:25.250459 [ 6665 ] {2644487e-9d28-4b3b-bebe-5365e5ac5da4} TCPHandler: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:25.369954 [ 6665 ] {97d4ae1a-0be1-42d6-87d1-63608b221f94} executeQuery: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35672) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SET max_memory_usage='20G';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:25.375269 [ 6665 ] {97d4ae1a-0be1-42d6-87d1-63608b221f94} TCPHandler: Code: 452. DB::Exception: Setting max_memory_usage shouldn't be greater than 10000000000. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:25.459885 [ 5056 ] {0566746a-5fea-4601-999d-2f644feaf77d} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary test_yxofxbmv.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35644) (comment: 02181_dictionary_attach_detach.sql) (in query: DETACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001222b88c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572c6b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:25.468453 [ 5056 ] {0566746a-5fea-4601-999d-2f644feaf77d} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary test_yxofxbmv.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x000000001222b88c 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572c6b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:25.517252 [ 6665 ] {00976cdb-14d8-4ee5-ac69-744bfd845c0c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35688) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:25.521150 [ 6665 ] {00976cdb-14d8-4ee5-ac69-744bfd845c0c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:25.536959 [ 5056 ] {a8069a19-eedc-44f0-8c64-e12022ce2253} executeQuery: Code: 80. DB::Exception: Cannot ATTACH TABLE test_yxofxbmv.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35644) (comment: 02181_dictionary_attach_detach.sql) (in query: ATTACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558d3e 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:14:25.540461 [ 5056 ] {a8069a19-eedc-44f0-8c64-e12022ce2253} TCPHandler: Code: 80. DB::Exception: Cannot ATTACH TABLE test_yxofxbmv.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558d3e 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:14:26.545872 [ 4191 ] {fb2ea430-587e-46e2-b3f1-d97d110a46ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34224) (comment: 01410_nullable_key_and_index.sql) (in query: SELECT * FROM nullable_key WHERE k IS NULL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:14:26.555208 [ 4191 ] {fb2ea430-587e-46e2-b3f1-d97d110a46ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:14:27.543509 [ 8172 ] {5b64c3c6-6d55-4ad1-bc90-7014252d4e5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 57 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35050) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT `__table1`.`value` AS `value`, `__table1`.`number` AS `number` FROM `test_lf4yt5w2`.`test_parallel_replicas_automatic_count_right_side` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:27.574407 [ 8172 ] {5b64c3c6-6d55-4ad1-bc90-7014252d4e5e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 57 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:27.697379 [ 6986 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_0_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 57 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35712) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfce7f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fe03 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:14:27.849706 [ 6986 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_0_pure} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 57 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfce7f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fe03 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:14:29.759753 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:30.121025 [ 4197 ] {908f3680-a8df-4322-9d5b-5b63ca436062} executeQuery: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35752) (comment: 01310_enum_comparison.sql) (in query: SELECT count() FROM enum WHERE x = 'xyz';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x00000000084d706b 4. /build/src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x0000000010c98064 5. /build/src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d038eb 6. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 8. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008806bf2 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ec606 10. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 11. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 16. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 17. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 18. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 19. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000011625f58 20. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654c69 21. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e915 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:30.133016 [ 4197 ] {908f3680-a8df-4322-9d5b-5b63ca436062} TCPHandler: Code: 691. DB::Exception: Unknown element 'xyz' for enum: while converting 'xyz' to Enum8('hello' = 1, 'world' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x00000000084d706b 4. /build/src/DataTypes/EnumValues.cpp:0: DB::EnumValues<_BitInt(8)>::getValue(StringRef, bool) const @ 0x0000000010c98064 5. /build/src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d038eb 6. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 8. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008806bf2 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ec606 10. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 11. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 16. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 17. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 18. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 19. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000011625f58 20. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654c69 21. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e915 22. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 23. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 24. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:30.134877 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:30.987976 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:31.358542 [ 8172 ] {4758e909-1731-4294-a93c-a1a08b1817f9} 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.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:31.361485 [ 8172 ] {4758e909-1731-4294-a93c-a1a08b1817f9} 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), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:31.464916 [ 8172 ] {c337d10c-c213-4e29-b278-9ae01ef2cc3f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.468710 [ 8172 ] {c337d10c-c213-4e29-b278-9ae01ef2cc3f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date: In scope SELECT YYYYMMDDToDate(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.560995 [ 8172 ] {ab0fca38-c4eb-4d85-874f-c2e14df997db} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.569349 [ 8172 ] {ab0fca38-c4eb-4d85-874f-c2e14df997db} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDToDate(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.632242 [ 8172 ] {e747367d-84b2-4661-90d6-fdc933fd0226} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.637878 [ 8172 ] {e747367d-84b2-4661-90d6-fdc933fd0226} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDToDate(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.788618 [ 8172 ] {ea63a38e-fdc7-4fa7-aa3c-1fad0cdafcf0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.798459 [ 8172 ] {ea63a38e-fdc7-4fa7-aa3c-1fad0cdafcf0} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDToDate(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.902559 [ 8172 ] {4243b44c-85ca-4481-9920-f45e661ec970} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.906013 [ 8172 ] {4243b44c-85ca-4481-9920-f45e661ec970} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDD' to function 'YYYYMMDDToDate'. Expected: Number, got: String: In scope SELECT YYYYMMDDToDate('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:31.929890 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:31.984964 [ 8172 ] {72de878e-f00e-4fbd-90dd-cd24a9e225d3} 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(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 09, 11);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:31.987723 [ 8172 ] {72de878e-f00e-4fbd-90dd-cd24a9e225d3} 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(2023, 9, 11). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:32.065690 [ 8172 ] {db631cd8-c27f-4b71-82d9-ee65998884f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(2023, 110);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:32.067725 [ 8172 ] {db631cd8-c27f-4b71-82d9-ee65998884f6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate(2023, 110). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000000703176b 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007030142 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionYYYYYMMDDToDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0bec72 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:14:32.809174 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:32.890318 [ 6665 ] {e003cb5c-4f43-4d83-86e8-e918e5763bd5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35824) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:32.912783 [ 6665 ] {e003cb5c-4f43-4d83-86e8-e918e5763bd5} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:33.365307 [ 8172 ] {a14e65ee-049e-4546-bea3-e2376da780f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35784) (comment: 02876_yyyymmddtodate.sql) (in query: SELECT YYYYMMDDToDate(19691231.1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:33.405963 [ 8172 ] {a14e65ee-049e-4546-bea3-e2376da780f4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:33.740261 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:34.099493 [ 2952 ] {c1256fa4-5f99-4419-a7a0-61f2e6cd1ae2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column val1): (while reading from part /var/lib/clickhouse/store/5e6/5e6abea0-e6dd-4ec9-9f5d-4473864bb210/all_1_1_0/ in table test_13.topk (5e6abea0-e6dd-4ec9-9f5d-4473864bb210) located on disk default of type local, from mark 29 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35640) (comment: 00981_topK_topKWeighted_long.sql) (in query: SELECT arraySort(topK(10)(val1)) FROM topk;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d65b12 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 2025.06.25 16:14:34.121116 [ 2952 ] {c1256fa4-5f99-4419-a7a0-61f2e6cd1ae2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column val1): (while reading from part /var/lib/clickhouse/store/5e6/5e6abea0-e6dd-4ec9-9f5d-4473864bb210/all_1_1_0/ in table test_13.topk (5e6abea0-e6dd-4ec9-9f5d-4473864bb210) located on disk default of type local, from mark 29 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d65b12 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 2025.06.25 16:14:34.756347 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:35.163099 [ 4197 ] {e77fff51-eaa5-4d02-88e5-2302e5127f78} StorageBuffer (test_13.buffer_table1__fuzz_24): Destination table test_13.merge_tree_table1 doesn't have column s. The default values are used. 2025.06.25 16:14:35.164061 [ 4197 ] {e77fff51-eaa5-4d02-88e5-2302e5127f78} StorageBuffer (test_13.buffer_table1__fuzz_24): Destination table test_13.merge_tree_table1 has no common columns with block in buffer. Block of data is skipped. 2025.06.25 16:14:35.211133 [ 4197 ] {e77fff51-eaa5-4d02-88e5-2302e5127f78} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50228) (comment: 00910_buffer_prewhere_different_types.sql) (in query: SELECT s FROM buffer_table1__fuzz_24 PREWHERE factorial(toNullable(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000789174b 4. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0cf7 5. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>) @ 0x0000000012fb0eca 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::FilterTransform* std::construct_at[abi:v15007]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x000000001163c55a 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000012519da3 8. /build/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 @ 0x0000000010bdafce 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012513292 12. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 13. /build/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&) @ 0x000000001166245c 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:14:35.216243 [ 4197 ] {e77fff51-eaa5-4d02-88e5-2302e5127f78} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000789174b 4. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0cf7 5. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>) @ 0x0000000012fb0eca 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::FilterTransform* std::construct_at[abi:v15007]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x000000001163c55a 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000012519da3 8. /build/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 @ 0x0000000010bdafce 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012513292 12. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 13. /build/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&) @ 0x000000001166245c 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:14:35.486314 [ 4197 ] {b2e019b2-25e8-4603-92a6-954742dd194c} StorageBuffer (test_13.buffer_table1__fuzz_24): Destination table test_13.merge_tree_table1 doesn't have column s. The default values are used. 2025.06.25 16:14:35.487912 [ 4197 ] {b2e019b2-25e8-4603-92a6-954742dd194c} StorageBuffer (test_13.buffer_table1__fuzz_24): Destination table test_13.merge_tree_table1 has no common columns with block in buffer. Block of data is skipped. 2025.06.25 16:14:35.492747 [ 4197 ] {b2e019b2-25e8-4603-92a6-954742dd194c} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50228) (comment: 00910_buffer_prewhere_different_types.sql) (in query: SELECT s FROM buffer_table1__fuzz_24 PREWHERE factorial(toNullable(10));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000789174b 4. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0cf7 5. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>) @ 0x0000000012fb0eca 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::FilterTransform* std::construct_at[abi:v15007]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x000000001163c55a 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000012519da3 8. /build/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 @ 0x0000000010bdafce 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012513292 12. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 13. /build/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&) @ 0x000000001166245c 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:14:35.500141 [ 4197 ] {b2e019b2-25e8-4603-92a6-954742dd194c} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt64) of column _CAST(3628800_Nullable(UInt64), 'Nullable(UInt64)'_String) for filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000789174b 4. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb0cf7 5. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::FilterTransform(DB::Block const&, std::shared_ptr, String, bool, bool, std::shared_ptr>) @ 0x0000000012fb0eca 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::FilterTransform* std::construct_at[abi:v15007]&, String&, bool&, DB::FilterTransform*>(DB::FilterTransform*, DB::Block const&, std::shared_ptr&, String&, bool&) @ 0x000000001163c55a 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000012519da3 8. /build/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 @ 0x0000000010bdafce 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012513292 12. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 13. /build/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&) @ 0x000000001166245c 14. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:14:35.627710 [ 6986 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_10M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 109 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35742) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:35.663822 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:35.707424 [ 6986 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_10M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 109 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:35.755951 [ 4197 ] {4f079dd7-8e61-45e6-8fec-ac05a4e2a2e4} StorageBuffer (test_13.buffer_table1__fuzz_28): Destination table test_13.merge_tree_table1 has different type of column x (UInt32 != Nullable(UInt32)). Data from destination table are converted. 2025.06.25 16:14:36.102677 [ 4197 ] {2a28edac-029a-428f-b49e-5bc514b7eebc} StorageBuffer (test_13.buffer_table1__fuzz_28): Destination table test_13.merge_tree_table1 has different type of column x (UInt32 != Nullable(UInt32)). Data from destination table are converted. 2025.06.25 16:14:36.199719 [ 2956 ] {5eb931e4-749c-4044-9476-f154e6277f76} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56820) (comment: 02147_arrow_duplicate_columns.sh) (in query: DROP DATABASE IF EXISTS test_shcbeafq ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:14:36.202481 [ 2956 ] {5eb931e4-749c-4044-9476-f154e6277f76} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:36.553184 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:36.974466 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_5M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column number): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 49 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50292) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:37.022871 [ 5174 ] {7eb69133-bac6-499d-8f47-86241aa25cef} 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.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: -- Error cases SELECT dateTimeToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.027042 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_5M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column number): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 49 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:37.033143 [ 5174 ] {7eb69133-bac6-499d-8f47-86241aa25cef} 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), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.102670 [ 5174 ] {c8ef3c2b-64b4-4ac5-9ed1-ae10e3b7e1bd} 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.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.112944 [ 5174 ] {c8ef3c2b-64b4-4ac5-9ed1-ae10e3b7e1bd} 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), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.245201 [ 5174 ] {cf009506-a80d-4ca4-bce5-77291e827b0d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b61fc32 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:37.265414 [ 5174 ] {cf009506-a80d-4ca4-bce5-77291e827b0d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b61fc32 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:37.374889 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:37.391626 [ 5174 ] {912acb9e-3e71-4269-9c8d-302f6e05c6c9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b6202f2 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:37.416623 [ 5174 ] {912acb9e-3e71-4269-9c8d-302f6e05c6c9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b6202f2 7. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 8. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 9. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:37.454120 [ 5174 ] {8f8135be-3d8d-400e-9629-5f8570eba2f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.458542 [ 5174 ] {8f8135be-3d8d-400e-9629-5f8570eba2f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.518010 [ 5174 ] {934f4fc1-251e-4c4a-b3bc-4dd6dc2ef80b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.520559 [ 5174 ] {934f4fc1-251e-4c4a-b3bc-4dd6dc2ef80b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:37.597580 [ 5174 ] {cca69ca8-acc3-4be2-961d-fa2404ee082a} executeQuery: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/snowflake.cpp:0: DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61fa70 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:37.602425 [ 5174 ] {cca69ca8-acc3-4be2-961d-fa2404ee082a} TCPHandler: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/snowflake.cpp:0: DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61fa70 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:37.662564 [ 5174 ] {0964dc4c-6f4a-463f-8618-87c6c86c66ee} executeQuery: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50316) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/snowflake.cpp:0: DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b62012d 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:37.665446 [ 5174 ] {0964dc4c-6f4a-463f-8618-87c6c86c66ee} TCPHandler: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/snowflake.cpp:0: DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b62012d 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:38.145010 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:38.265796 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_1M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 62 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50324) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:38.324430 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_1M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 62 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:38.374258 [ 6985 ] {029b8e86-5b6f-4d6c-b845-a164540aa044} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34106) (comment: 02725_database_hdfs.sh) (in query: insert into table function hdfs('hdfs://localhost:12222/test_02725_1.tsv', 'TSV', 'column1 UInt32, column2 UInt32, column3 UInt32') select 1, 2, 3 settings hdfs_truncate_on_insert=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000105daf2e 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x0000000010706139 6. /build/contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000107076a7 7. /build/src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000010598ecf 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x0000000010594310 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001058f8b4 10. /build/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&) @ 0x00000000130561e2 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 12. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 14. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:38.380045 [ 6985 ] {029b8e86-5b6f-4d6c-b845-a164540aa044} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000105daf2e 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x0000000010706139 6. /build/contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000107076a7 7. /build/src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000010598ecf 8. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x0000000010594310 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001058f8b4 10. /build/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&) @ 0x00000000130561e2 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x00000000115f6aee 12. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x00000000115f7615 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f8ef7 14. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:38.884782 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:39.389988 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_300k_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column number): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 18 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50368) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: SELECT sum(value) FROM test_parallel_replicas_automatic_left_side INNER JOIN test_parallel_replicas_automatic_count_right_side USING number format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:39.540790 [ 5054 ] {02784_automatic_parallel_replicas_join-test_lf4yt5w2_simple_join_300k_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column number): (while reading from part /var/lib/clickhouse/store/84f/84fbec55-0395-425b-8a17-016945581045/all_1_1_0/ in table test_lf4yt5w2.test_parallel_replicas_automatic_count_right_side (84fbec55-0395-425b-8a17-016945581045) located on disk default of type local, from mark 18 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d34bdf 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:14:39.773663 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:40.664078 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:41.171256 [ 6398 ] {ac0769ed-faa3-40f2-bd0e-8b99a24555f6} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50380) (comment: 00386_has_column_in_table.sql) (in query: /* bad queries */ SELECT hasColumnInTable('', '', '');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/hasColumnInTable.cpp:115: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093643a3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:41.173064 [ 6398 ] {ac0769ed-faa3-40f2-bd0e-8b99a24555f6} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/hasColumnInTable.cpp:115: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093643a3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:41.341152 [ 6398 ] {e7d11dac-f978-4986-bae8-c21ea471d64c} executeQuery: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50380) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable('', 't', 'c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011176ed8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 6. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:41.356230 [ 6398 ] {e7d11dac-f978-4986-bae8-c21ea471d64c} TCPHandler: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/contrib/llvm-project/libcxx/include/optional:897: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011176ed8 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 6. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:41.449524 [ 6398 ] {2979f60f-0de1-4763-b43e-f0606752d399} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50380) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable(currentDatabase(), '', 'c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/hasColumnInTable.cpp:115: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093643a3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:41.454004 [ 6398 ] {2979f60f-0de1-4763-b43e-f0606752d399} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/hasColumnInTable.cpp:115: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093643a3 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:14:41.524431 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:41.579402 [ 6398 ] {1a4fef6f-de23-464f-8008-f530565a35c8} executeQuery: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50380) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable('d', 't', 's');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177802 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 6. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:41.581300 [ 6398 ] {1a4fef6f-de23-464f-8008-f530565a35c8} TCPHandler: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177802 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 6. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:14:41.766852 [ 6398 ] {52aea2e6-dbf6-4bb6-9a94-262c06698afb} executeQuery: Code: 60. DB::Exception: Table test_11.t does not exist. Maybe you meant test_w2x3dsj5.t?: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50380) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable(currentDatabase(), 't', 's');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:14:41.770423 [ 6398 ] {52aea2e6-dbf6-4bb6-9a94-262c06698afb} TCPHandler: Code: 60. DB::Exception: Table test_11.t does not exist. Maybe you meant test_w2x3dsj5.t?: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Functions/hasColumnInTable.cpp:123: DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009363a5b 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:14:42.382354 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:43.213220 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:43.260399 [ 6398 ] {aab9c34f-965f-4338-9c07-d51bac2d25e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50496) (comment: 03273_select_from_explain_ast_non_select.sql) (in query: SELECT * FROM ( EXPLAIN AST SELECT * FROM numbers(10) );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:43.261571 [ 6398 ] {aab9c34f-965f-4338-9c07-d51bac2d25e3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:44.104353 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:45.063941 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:45.984892 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:46.844763 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:46.980055 [ 5174 ] {e56dcaf9-2e7d-4ae2-9b04-0ad948a6b2e5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50468) (comment: 02495_analyzer_storage_join.sql) (in query: SELECT a FROM t ALL RIGHT JOIN tj USING (key1, key2) ORDER BY key1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:46.984147 [ 5174 ] {e56dcaf9-2e7d-4ae2-9b04-0ad948a6b2e5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:14:47.291930 [ 6398 ] {440b91a3-1040-4b21-a0c2-f95522d9e9e3} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50518) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1229: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000012a40a57 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x0000000012a52243 6. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000012a3f324 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000012a3472e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000012a3e798 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facebc 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 14. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:47.302920 [ 6398 ] {440b91a3-1040-4b21-a0c2-f95522d9e9e3} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1229: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x0000000012a40a57 5. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:91: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x0000000012a52243 6. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:0: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x0000000012a3f324 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:463: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x0000000012a3472e 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x0000000012a3e798 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facebc 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 13. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 14. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 15. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:47.759437 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:48.048703 [ 6398 ] {35eaf069-b362-41de-b5bd-6d74656e9dca} 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.10505.altinitytest (altinity build)) (from [::1]:50518) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (in query: SELECT x FROM quorum2 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:14:48.055792 [ 6398 ] {35eaf069-b362-41de-b5bd-6d74656e9dca} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:14:48.435139 [ 4191 ] {93714485-dbcf-41bd-ad08-95f574446f7b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46500) (comment: 02226_filesystem_cache_profile_events.sh) (in query: select queryID() from (SELECT * FROM test_02226 LIMIT 10) limit 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:48.447889 [ 4191 ] {93714485-dbcf-41bd-ad08-95f574446f7b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:14:48.564982 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:49.504016 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:50.403091 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:51.034860 [ 6379 ] {71906479-3aa4-4fc9-9346-5597d2333300} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46590) (comment: 01952_optimize_distributed_group_by_sharding_key.sql) (in query: set enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:51.045860 [ 6379 ] {71906479-3aa4-4fc9-9346-5597d2333300} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:51.200170 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:52.035773 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:52.681854 [ 4191 ] {9496165c-3edb-485b-ba1a-13af4012f04c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52116) (comment: 03128_system_unload_primary_key.sql) (in query: DROP DATABASE IF EXISTS test_kj9wueo2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:14:52.683303 [ 4191 ] {9496165c-3edb-485b-ba1a-13af4012f04c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:52.868306 [ 5056 ] {ac9b171a-981a-4f6c-b667-35bc55818520} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52122) (comment: 03128_system_unload_primary_key.sql) (in query: DROP DATABASE IF EXISTS test_kj9wueo2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:14:52.870781 [ 5056 ] {ac9b171a-981a-4f6c-b667-35bc55818520} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:52.899529 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:53.296556 [ 6379 ] {c88d2bc4-b6c7-4c67-bcd2-5b25a0c8eb86} 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.10505.altinitytest (altinity build)) (from [::1]:46688) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:53.314175 [ 6379 ] {c88d2bc4-b6c7-4c67-bcd2-5b25a0c8eb86} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:53.711432 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:53.783968 [ 6379 ] {12c2892d-9199-465b-ba90-ce685286b5a1} executeQuery: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_11.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.10505.altinitytest (altinity build)) (from [::1]:46704) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:53.805132 [ 6379 ] {12c2892d-9199-465b-ba90-ce685286b5a1} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_11.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:53.819122 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_29_55_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:54.250781 [ 4191 ] {450a7d68-aed0-4237-8b4e-cee1d021ba41} 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.10505.altinitytest (altinity build)) (from [::1]:44448) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:54.264018 [ 4191 ] {450a7d68-aed0-4237-8b4e-cee1d021ba41} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:54.553208 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:54.761353 [ 6836 ] {4b5f1f88-0079-49e0-81e2-268827298939} 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.10505.altinitytest (altinity build)) (from [::1]:44480) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:54.779893 [ 6836 ] {4b5f1f88-0079-49e0-81e2-268827298939} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:54.960609 [ 3628 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_29_55_5}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:54.989962 [ 6379 ] {7a4d659d-9b66-4b49-8fb7-1121a7e0da2c} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46732) (comment: 02724_limit_num_mutations.sh) (in query: INSERT INTO t_limit_mutations VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb736 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:14:54.994049 [ 6379 ] {7a4d659d-9b66-4b49-8fb7-1121a7e0da2c} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb736 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:14:55.209853 [ 6379 ] {0c3708df-4ac7-429c-9598-72328a710e7b} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53640) (comment: 02724_limit_num_mutations.sh) (in query: DROP DATABASE IF EXISTS test_q8l09y0g ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157212a 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:55.213266 [ 6379 ] {0c3708df-4ac7-429c-9598-72328a710e7b} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157212a 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:55.309056 [ 5056 ] {3dd06338-b67a-4400-b954-a1c9eb87f94c} 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.10505.altinitytest (altinity build)) (from [::1]:44496) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:55.328719 [ 5056 ] {3dd06338-b67a-4400-b954-a1c9eb87f94c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:55.435575 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:55.884869 [ 6379 ] {b389f171-d869-4754-bd5a-635cbee2ce16} 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.10505.altinitytest (altinity build)) (from [::1]:44512) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:55.893967 [ 6379 ] {b389f171-d869-4754-bd5a-635cbee2ce16} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:56.322401 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:56.350728 [ 6379 ] {652d03c3-ac78-43b4-aaa0-f3c7e377bd33} 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.10505.altinitytest (altinity build)) (from [::1]:44526) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:56.369175 [ 6379 ] {652d03c3-ac78-43b4-aaa0-f3c7e377bd33} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:56.820762 [ 6379 ] {fee2eb5c-ae37-4ca7-9865-6343e03f9504} 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.10505.altinitytest (altinity build)) (from [::1]:44566) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:56.833222 [ 6379 ] {fee2eb5c-ae37-4ca7-9865-6343e03f9504} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:57.167785 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:57.322440 [ 4191 ] {9974bf8e-177f-4cbf-b4d5-b379c22e69bb} 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.10505.altinitytest (altinity build)) (from [::1]:44588) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:57.338499 [ 4191 ] {9974bf8e-177f-4cbf-b4d5-b379c22e69bb} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:57.836522 [ 6836 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:57.853351 [ 4191 ] {155126d7-8754-4c15-b14c-30d02402dc93} 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.10505.altinitytest (altinity build)) (from [::1]:44612) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:57.859926 [ 4191 ] {155126d7-8754-4c15-b14c-30d02402dc93} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:58.031799 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:58.314318 [ 6379 ] {14f37c1b-3095-4892-bf53-07c0a376c255} 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.10505.altinitytest (altinity build)) (from [::1]:44632) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:58.317501 [ 6379 ] {14f37c1b-3095-4892-bf53-07c0a376c255} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:58.534222 [ 6379 ] {7d71956f-2ff9-4ab0-99a8-76ede88f78d2} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44640) (comment: 02226_filesystem_cache_profile_events.sh) (in query: SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value LIMIT 10 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:58.570829 [ 6379 ] {7d71956f-2ff9-4ab0-99a8-76ede88f78d2} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02226' in scope SELECT * FROM test_02226 WHERE value LIKE '%abc%' ORDER BY value ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:14:58.714080 [ 6379 ] {667eddfb-4a3f-4c61-8975-4fe943b7a67e} executeQuery: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44642) (comment: 02226_filesystem_cache_profile_events.sh) (in query: DROP TABLE test_02226), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:58.729300 [ 6379 ] {667eddfb-4a3f-4c61-8975-4fe943b7a67e} TCPHandler: Code: 60. DB::Exception: Table test_5tylpovm.test_02226 does not exist. Maybe you meant test_13.test_02152?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x00000000070b87cb 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e18402 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:14:58.830895 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:58.865262 [ 4191 ] {b0a2fd98-1a5b-4d8f-b4b0-f70c601d1a62} 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.10505.altinitytest (altinity build)) (from [::1]:44646) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:58.881515 [ 4191 ] {b0a2fd98-1a5b-4d8f-b4b0-f70c601d1a62} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:59.281964 [ 4191 ] {7c7a6cb2-b940-4b61-9b14-e0124722377f} 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.10505.altinitytest (altinity build)) (from [::1]:44676) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:59.297069 [ 4191 ] {7c7a6cb2-b940-4b61-9b14-e0124722377f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:14:59.651372 [ 3304 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:14:59.667478 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:14:59.851684 [ 6379 ] {b2f33253-0290-43b9-a5e0-631b835a4da5} 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.10505.altinitytest (altinity build)) (from [::1]:44690) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:14:59.932805 [ 6379 ] {b2f33253-0290-43b9-a5e0-631b835a4da5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:15:00.386903 [ 6379 ] {fa23b595-f643-412a-b2f5-e4faad1e91c3} 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.10505.altinitytest (altinity build)) (from [::1]:44730) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:00.413509 [ 6379 ] {fa23b595-f643-412a-b2f5-e4faad1e91c3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:00.559391 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:00.656346 [ 3103 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:00.898529 [ 6379 ] {60f40fd3-febd-4368-b21f-f6c1d7538052} 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.10505.altinitytest (altinity build)) (from [::1]:44752) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:00.906245 [ 6379 ] {60f40fd3-febd-4368-b21f-f6c1d7538052} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:01.311251 [ 6379 ] {4abe8841-7e47-4e6b-878c-9bc03486d5a0} 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.10505.altinitytest (altinity build)) (from [::1]:44772) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:01.317531 [ 6379 ] {4abe8841-7e47-4e6b-878c-9bc03486d5a0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:01.361719 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:01.662858 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:02.045361 [ 6379 ] {154ea987-226e-43dd-b0a3-e13caa476ba3} 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.10505.altinitytest (altinity build)) (from [::1]:44808) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000001105a68f 9. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104eec5 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:02.061577 [ 6379 ] {154ea987-226e-43dd-b0a3-e13caa476ba3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000001105a68f 9. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104eec5 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:02.241985 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:02.667571 [ 3296 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:02.929323 [ 6379 ] {767e6f88-2aa8-451d-959e-b0e77afee300} 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.10505.altinitytest (altinity build)) (from [::1]:44832) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:02.937259 [ 6379 ] {767e6f88-2aa8-451d-959e-b0e77afee300} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:03.072538 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:03.672525 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:03.926800 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:04.023089 [ 3626 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8615fb30-d08c-48c1-a41a-01099e1320ba::202506_1_45_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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:04.677508 [ 3223 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:04.751057 [ 6379 ] {15d0c802-a578-488f-8c62-8cdb60ac4a19} 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.10505.altinitytest (altinity build)) (from [::1]:53160) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:04.755677 [ 6379 ] {15d0c802-a578-488f-8c62-8cdb60ac4a19} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:04.803225 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:05.289313 [ 6836 ] {6d923966-517f-4a7b-b6e9-d5abb363be0e} 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_11.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.10505.altinitytest (altinity build)) (from [::1]:53196) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:05.293658 [ 6836 ] {6d923966-517f-4a7b-b6e9-d5abb363be0e} 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_11.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:05.616359 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:05.674872 [ 6986 ] {457526b6-d9e9-4400-85fd-1add85fffb86} 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.10505.altinitytest (altinity build)) (from [::1]:53218) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:05.681093 [ 3199 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:05.689855 [ 6986 ] {457526b6-d9e9-4400-85fd-1add85fffb86} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:06.205088 [ 6379 ] {2ea4add3-650e-4b2d-bdcf-5ac7de94a947} 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.10505.altinitytest (altinity build)) (from [::1]:53222) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:06.215231 [ 6379 ] {2ea4add3-650e-4b2d-bdcf-5ac7de94a947} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:06.446289 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:06.683146 [ 3205 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:06.696170 [ 6836 ] {33b90889-7fb4-4ee4-a1d1-637c4a964e8c} 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.10505.altinitytest (altinity build)) (from [::1]:53264) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:06.710259 [ 6836 ] {33b90889-7fb4-4ee4-a1d1-637c4a964e8c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:07.252823 [ 6986 ] {d5ba68bf-4b64-45c3-8a33-8c388fec53ee} 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.10505.altinitytest (altinity build)) (from [::1]:53282) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:07.329041 [ 6986 ] {d5ba68bf-4b64-45c3-8a33-8c388fec53ee} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:07.340487 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:07.688326 [ 3251 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:07.819405 [ 6379 ] {9b931911-450f-4292-a32f-62f623438612} 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.10505.altinitytest (altinity build)) (from [::1]:53320) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:07.837632 [ 6379 ] {9b931911-450f-4292-a32f-62f623438612} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:08.186438 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:08.336979 [ 6379 ] {0ce0f51a-aca6-4590-9837-97dcd2275430} 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.10505.altinitytest (altinity build)) (from [::1]:53344) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:08.358942 [ 6379 ] {0ce0f51a-aca6-4590-9837-97dcd2275430} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:08.743888 [ 3039 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:08.777924 [ 6379 ] {e58dd8a8-a888-4146-87c2-9ec36f0f1730} 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.10505.altinitytest (altinity build)) (from [::1]:53384) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:08.786472 [ 6379 ] {e58dd8a8-a888-4146-87c2-9ec36f0f1730} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:09.112607 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:09.369125 [ 8172 ] {dc98cbf7-02da-4284-859c-bd54c57fa790} 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.10505.altinitytest (altinity build)) (from [::1]:53412) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:09.379275 [ 8172 ] {dc98cbf7-02da-4284-859c-bd54c57fa790} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:09.748667 [ 3004 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:09.928189 [ 6986 ] {aca733be-8d1b-4d84-bd04-a6e73fc492be} 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.10505.altinitytest (altinity build)) (from [::1]:53438) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:09.937508 [ 6986 ] {aca733be-8d1b-4d84-bd04-a6e73fc492be} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:09.980015 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:10.469977 [ 8172 ] {c308f2e9-bb57-4005-a4bb-c94f33a7ffe7} 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.10505.altinitytest (altinity build)) (from [::1]:53462) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:10.501417 [ 8172 ] {c308f2e9-bb57-4005-a4bb-c94f33a7ffe7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:10.745015 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:10.755613 [ 3270 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:10.891285 [ 6986 ] {fa016c47-269a-487e-b27f-c45231aefc87} 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.10505.altinitytest (altinity build)) (from [::1]:53508) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:10.916227 [ 6986 ] {fa016c47-269a-487e-b27f-c45231aefc87} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:11.426260 [ 8172 ] {7de18f1f-1580-4e08-ad52-a21b39c252dd} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53526) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_flat_custom), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:11.429303 [ 8172 ] {7de18f1f-1580-4e08-ad52-a21b39c252dd} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:11.453851 [ 2956 ] {87b0bd4e-e704-48c7-b109-620b80a76209} 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.10505.altinitytest (altinity build)) (from [::1]:53540) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:11.481988 [ 2956 ] {87b0bd4e-e704-48c7-b109-620b80a76209} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x0000000011092939 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x000000001108a97d 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108c15c 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 10. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:11.527517 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:11.759544 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:11.934642 [ 2956 ] {cea62a2c-ac33-4713-816a-2bdd38479335} 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.10505.altinitytest (altinity build)) (from [::1]:53570) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:11.961165 [ 2956 ] {cea62a2c-ac33-4713-816a-2bdd38479335} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:12.349045 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:12.380950 [ 2956 ] {39b17223-d772-4e2e-9e10-92317aff7c6b} 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.10505.altinitytest (altinity build)) (from [::1]:53594) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:12.405144 [ 2956 ] {39b17223-d772-4e2e-9e10-92317aff7c6b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:12.764896 [ 3247 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:12.897794 [ 2956 ] {52da7be9-c0ec-43e4-a94e-1621d928d216} 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.10505.altinitytest (altinity build)) (from [::1]:53620) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:12.907870 [ 2956 ] {52da7be9-c0ec-43e4-a94e-1621d928d216} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:13.205075 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:13.409982 [ 2956 ] {595ad32c-01d9-4db6-b4af-9e25bf3850a5} 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.10505.altinitytest (altinity build)) (from [::1]:53640) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000001105a68f 9. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104eec5 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:13.421225 [ 2956 ] {595ad32c-01d9-4db6-b4af-9e25bf3850a5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000001105a68f 9. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104eec5 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:15:13.769799 [ 3352 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:13.955249 [ 2956 ] {20890a06-761c-4e8a-ad07-71f53f04a071} 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.10505.altinitytest (altinity build)) (from [::1]:53658) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:13.971582 [ 2956 ] {20890a06-761c-4e8a-ad07-71f53f04a071} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:14.081496 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:14.773994 [ 3168 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:14.900765 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:15.722546 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:15.779793 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:16.592627 [ 2956 ] {2d0ea74d-e6c1-42c0-989d-510aadcba189} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_11.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.10505.altinitytest (altinity build)) (from [::1]:38102) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:16.609328 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:16.614061 [ 2956 ] {2d0ea74d-e6c1-42c0-989d-510aadcba189} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_11.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:16.784867 [ 3041 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:17.235947 [ 2956 ] {58db52b9-417d-4491-b750-aded8c33262a} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_11.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.10505.altinitytest (altinity build)) (from [::1]:38144) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e8bc 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:17.249950 [ 2956 ] {58db52b9-417d-4491-b750-aded8c33262a} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_11.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e8bc 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:17.403686 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:17.684431 [ 8172 ] {ad97ab98-0d63-4afb-853a-4ed9197a2931} 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.10505.altinitytest (altinity build)) (from [::1]:38182) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:17.705163 [ 8172 ] {ad97ab98-0d63-4afb-853a-4ed9197a2931} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:17.856243 [ 3212 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:18.203608 [ 2956 ] {64dff65b-bf70-4e30-a918-cf5f4e2814bc} 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.10505.altinitytest (altinity build)) (from [::1]:38204) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e8bc 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:18.217462 [ 2956 ] {64dff65b-bf70-4e30-a918-cf5f4e2814bc} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e8bc 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:15:18.252519 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:18.678920 [ 6985 ] {6f314a7f-843b-4167-9850-03b3e5863146} 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.10505.altinitytest (altinity build)) (from [::1]:38244) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:18.734514 [ 6985 ] {6f314a7f-843b-4167-9850-03b3e5863146} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:18.860636 [ 3161 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:19.130144 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:19.164388 [ 6155 ] {82b4c312-aaec-41b7-a277-ce3078e6d6ec} 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.10505.altinitytest (altinity build)) (from [::1]:38294) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:19.207442 [ 6155 ] {82b4c312-aaec-41b7-a277-ce3078e6d6ec} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:19.718220 [ 6398 ] {1f0c1cc7-b8d0-40a7-80a0-0c08ab174a11} 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.10505.altinitytest (altinity build)) (from [::1]:38298) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:19.738725 [ 6398 ] {1f0c1cc7-b8d0-40a7-80a0-0c08ab174a11} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:19.866231 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:20.094959 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:20.875975 [ 3135 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:21.010791 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:21.089192 [ 6398 ] {2630c3be-607c-46c4-97b2-14cf3b680bb8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38368) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_hashed), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:21.112790 [ 6398 ] {2630c3be-607c-46c4-97b2-14cf3b680bb8} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:21.879996 [ 3280 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:22.071473 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:22.886482 [ 3141 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:23.041086 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:23.891083 [ 3096 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:23.967899 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:24.845362 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:24.906199 [ 3487 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:25.787025 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:25.911812 [ 3050 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:26.436980 [ 6398 ] {db176de1-f97c-406a-850d-283059376a47} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34968) (comment: 02530_dictionaries_update_field.sh) (in query: SELECT key, value FROM dict_hashed_custom ORDER BY key ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:26.457328 [ 6398 ] {db176de1-f97c-406a-850d-283059376a47} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=756, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:26.460123 [ 5054 ] {808f3b21-aa07-4552-8d2e-ff8fc1dee00d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34916) (comment: 02974_analyzer_array_join_subcolumn.sql) (in query: SELECT pe, pe.values.a FROM (SELECT * FROM t2) ARRAY JOIN pe SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:26.469091 [ 5054 ] {808f3b21-aa07-4552-8d2e-ff8fc1dee00d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:15:26.666605 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:26.916243 [ 3056 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:27.732267 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:27.965179 [ 3214 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:28.627524 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:28.971790 [ 3215 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:29.483483 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:29.977968 [ 3370 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:30.431411 [ 2952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:30.982993 [ 3515 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:31.331520 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:31.366723 [ 6155 ] {3fab2ab9-c80d-437a-9aad-ed513380ddf0} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35120) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_hashed_custom), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:31.377083 [ 6155 ] {3fab2ab9-c80d-437a-9aad-ed513380ddf0} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:31.775959 [ 6398 ] {b7f92f86-1851-4962-b58d-1d71b14a49e8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54054) (comment: 01113_local_dictionary_type_conversion.sql) (in query: DROP DATABASE IF EXISTS test_4jnxst15 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:15:31.789050 [ 6398 ] {b7f92f86-1851-4962-b58d-1d71b14a49e8} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:31.989984 [ 3053 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:32.268821 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:32.268883 [ 5174 ] {1612c1b9-e88c-4723-940c-115da0d2457a} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.07 MiB (attempt to allocate chunk of 1118807 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01900_kill_mutation_parallel_long.sh) (in query: /* ddl_entry=query-0000000089 */ ALTER TABLE test_11.data_01900_1 UPDATE s = 'foo_2' WHERE 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000c66c359 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b931 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 9. /build/src/IO/BufferWithOwnMemory.h:50: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000c6cccfb 10. /build/src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000c6cc2ce 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000c7b7350 12. /build/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&) @ 0x0000000010f00027 13. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9672 14. /build/src/Storages/MergeTree/MergeTreeMutationEntry.cpp:0: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x0000000012aa42b1 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7a27e 16. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cdce 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 18. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 22. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 23. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 24. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 26. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 27. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:15:32.322532 [ 5174 ] {1612c1b9-e88c-4723-940c-115da0d2457a} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.07 MiB (attempt to allocate chunk of 1118807 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35140) (comment: 01900_kill_mutation_parallel_long.sh) (in query: alter table data_01900_1 update s = 'foo_2' where 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000c66c359 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b931 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 9. /build/src/IO/BufferWithOwnMemory.h:50: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000c6cccfb 10. /build/src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000c6cc2ce 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000c7b7350 12. /build/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&) @ 0x0000000010f00027 13. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9672 14. /build/src/Storages/MergeTree/MergeTreeMutationEntry.cpp:0: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x0000000012aa42b1 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7a27e 16. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cdce 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 18. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 22. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 23. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 24. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 26. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 27. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:15:32.339958 [ 5174 ] {1612c1b9-e88c-4723-940c-115da0d2457a} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.07 MiB (attempt to allocate chunk of 1118807 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000c66c359 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b931 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 9. /build/src/IO/BufferWithOwnMemory.h:50: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000c6cccfb 10. /build/src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000c6cc2ce 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000c7b7350 12. /build/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&) @ 0x0000000010f00027 13. /build/src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000010ef9672 14. /build/src/Storages/MergeTree/MergeTreeMutationEntry.cpp:0: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x0000000012aa42b1 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7a27e 16. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7cdce 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 18. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 22. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 23. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 24. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 26. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 27. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:15:32.995955 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:33.293800 [ 3637 ] {0534d8dd-8fd8-42e3-8cca-6dbe4a2e0cce::all_1_1_0_2} 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.10505.altinitytest (altinity build)) 2025.06.25 16:15:33.295881 [ 3637 ] {0534d8dd-8fd8-42e3-8cca-6dbe4a2e0cce::all_1_1_0_2} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:33.317353 [ 6665 ] {6419b4d0-0ab6-4667-a9fd-91ac16b5a53d} 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=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01900_kill_mutation_parallel_long.sh) (in query: /* ddl_entry=query-0000000090 */ ALTER TABLE test_11.data_01900_2 UPDATE s = 'bar_1' WHERE 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x00000000128c206b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1fa3 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bfba 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7ce44 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:15:33.352045 [ 6665 ] {6419b4d0-0ab6-4667-a9fd-91ac16b5a53d} 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=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:35202) (comment: 01900_kill_mutation_parallel_long.sh) (in query: alter table data_01900_2 update s = 'bar_1' where 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x00000000128c206b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1fa3 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bfba 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7ce44 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:15:33.359210 [ 6665 ] {6419b4d0-0ab6-4667-a9fd-91ac16b5a53d} 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=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x00000000128c206b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1fa3 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bfba 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7ce44 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153dfce 16. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:15:33.521484 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:33.753289 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_29_61_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:34.003116 [ 3082 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:34.442399 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:34.825139 [ 5056 ] {1d37bf4d-e638-4470-97a6-abde8b68adcf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35238) (comment: 01104_distributed_numbers_test.sql) (in query: SELECT sum(number) FROM (select * from remote('127.0.0.{1,1,1}', system.numbers) AS n WHERE n.number = 100 LIMIT 3) SETTINGS max_threads = 2, prefer_localhost_replica=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:34.836201 [ 5056 ] {1d37bf4d-e638-4470-97a6-abde8b68adcf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:35.005972 [ 3381 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:35.229845 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:35.533140 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_29_61_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:36.009800 [ 3279 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:36.109711 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:37.006565 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:37.014906 [ 3221 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:37.818499 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:38.019434 [ 3013 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:38.285665 [ 2952 ] {3aa4348e-b82f-4141-af4c-8f070f451eb8} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02490_replacing_merge_tree_is_deleted_column.sql) (in query: /* ddl_entry=query-0000000092 */ CREATE TABLE test_11.test UUID 'f56f1299-7fa9-4b81-8078-c658069e8b06' (`uid` String, `version` UInt32, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(version) ORDER BY uid SETTINGS allow_experimental_replacing_merge_with_cleanup = 1, index_granularity = 37876, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 481961702, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25811402, merge_max_block_size = 24123, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4299041753, vertical_merge_algorithm_min_rows_to_activate = 524763, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 23130275, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74861, primary_key_compress_block_size = 46712), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:38.331157 [ 2952 ] {3aa4348e-b82f-4141-af4c-8f070f451eb8} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34442) (comment: 02490_replacing_merge_tree_is_deleted_column.sql) (in query: CREATE TABLE test (`uid` String, `version` UInt32, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(version) ORDER BY uid SETTINGS allow_experimental_replacing_merge_with_cleanup = 1, index_granularity = 37876, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 481961702, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25811402, merge_max_block_size = 24123, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4299041753, vertical_merge_algorithm_min_rows_to_activate = 524763, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 23130275, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74861, primary_key_compress_block_size = 46712), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:38.333406 [ 2952 ] {3aa4348e-b82f-4141-af4c-8f070f451eb8} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:38.638930 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:39.024051 [ 3337 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:39.106482 [ 2952 ] {01bd52c3-0cc4-441c-90ea-9f29a3d70902} 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.10505.altinitytest (altinity build)) (from [::1]:34472) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_0::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x000000000f998363 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/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 @ 0x0000000010201b1d 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bca57 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000958a83a 11. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 12. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 13. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:15:39.113213 [ 2952 ] {01bd52c3-0cc4-441c-90ea-9f29a3d70902} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: DB::registerAggregateFunctionSumMap(DB::AggregateFunctionFactory&)::$_0::operator()(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) const @ 0x000000000f998363 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/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 @ 0x0000000010201b1d 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000104bca57 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000958a83a 11. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 12. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 13. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:15:39.478100 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:40.029087 [ 3479 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:40.067738 [ 6379 ] {5b12b346-ca23-4f4e-9ca9-7971ebadd575} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34510) (comment: 02530_dictionaries_update_field.sh) (in query: SELECT key, value FROM dict_complex_key_hashed ORDER BY key ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:15:40.088418 [ 6379 ] {5b12b346-ca23-4f4e-9ca9-7971ebadd575} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:15:40.374788 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:41.037375 [ 3068 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:41.219192 [ 6379 ] {a0c48686-e144-439c-9839-ec245b796412} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34552) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_complex_key_hashed), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:41.231831 [ 6379 ] {a0c48686-e144-439c-9839-ec245b796412} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:41.291835 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:42.041726 [ 3356 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:42.188455 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:42.979027 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:43.046512 [ 3382 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:43.888501 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:44.050997 [ 3255 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:44.552648 [ 2952 ] {4baaef31-c921-4820-9249-9e619502e576} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:15:44.562275 [ 2952 ] {4baaef31-c921-4820-9249-9e619502e576} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34590) (comment: 01037_zookeeper_check_table_empty_pk.sql) (in query: CREATE TABLE replicated_mt_without_pk (`SomeField1` Int64, `SomeField2` Double) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01037/replicated_mt_without_pk', '1') ORDER BY tuple() SETTINGS index_granularity = 42940, min_bytes_for_wide_part = 68012035, ratio_of_defaults_for_sparse_serialization = 0.07488556206226349, replace_long_file_name_to_hash = false, max_file_name_length = 94, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 85138273, compact_parts_max_granules_to_buffer = 165, compact_parts_merge_max_bytes_to_prefetch_part = 7441229, merge_max_block_size = 15791, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4903815530, index_granularity_bytes = 219659, concurrent_part_removal_threshold = 18, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 10899, primary_key_compress_block_size = 73818), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:44.572065 [ 2952 ] {4baaef31-c921-4820-9249-9e619502e576} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:44.755281 [ 2952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:45.055485 [ 3106 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:45.668397 [ 6379 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:46.059639 [ 3283 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:46.111745 [ 6665 ] {06c0b006-a9e3-41d7-b59d-688ba42e584f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column is_initial_query): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_1_41_8/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 7555): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34378) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (in query: select splitByString('IN', query)[-1] from system.query_log where event_date >= yesterday() and event_time > now() - interval 1 hour and not is_initial_query and query not like '%system%query_log%' and query like concat('%', currentDatabase(), '%AS%id_no%') and type = 'QueryFinish' order by query;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2dbd8 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult const&, unsigned long&) @ 0x00000000128eb299 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:984: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9928 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:15:46.144209 [ 6665 ] {06c0b006-a9e3-41d7-b59d-688ba42e584f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column is_initial_query): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_1_41_8/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 7555): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2dbd8 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult const&, unsigned long&) @ 0x00000000128eb299 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:984: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9928 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:15:46.572593 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:47.061886 [ 3002 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:47.460654 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:47.953628 [ 6986 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:48.067092 [ 3471 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:48.307744 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:49.058753 [ 2952 ] {9a320b52-dbb1-49dc-817c-0c12bc1e8942} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54006) (comment: 00458_merge_type_cast.sql) (in query: DROP TABLE u64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:49.071196 [ 3302 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:49.076558 [ 2952 ] {9a320b52-dbb1-49dc-817c-0c12bc1e8942} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:49.202602 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:50.083528 [ 3305 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:50.106034 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:50.546072 [ 5777 ] {} ExternalDictionariesLoader: Could not update external dictionary '809f0fd9-5c0b-4405-b1c7-e4ea5ecdc82b', leaving the previous version, next update is scheduled at 2025-06-25 16:15:56: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): while reading column key at /var/lib/clickhouse/store/ea2/ea2a6f81-a431-462c-94bc-6f2478d20ff0/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80da88 14. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 15. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3ff0 17. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3001f 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/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>>>&) @ 0x00000000124f64ce 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f59cc 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Dictionaries/DictionaryHelpers.h:602: void DB::mergeBlockWithPipe<(DB::DictionaryKeyType)0>(unsigned long, DB::Block&, DB::QueryPipeline) @ 0x000000000c9e6331 29. /build/src/Dictionaries/FlatDictionary.cpp:0: DB::FlatDictionary::updateData() @ 0x000000000c9cf0a0 30. /build/src/Dictionaries/FlatDictionary.cpp:0: DB::FlatDictionary::loadData() @ 0x000000000c9c9bad 31. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:50.701145 [ 11749 ] {6413b61d-46f7-4a1a-8e55-8f0bec946a88} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52100) (comment: 02784_parallel_replicas_automatic_decision_join.sh) (in query: DROP DATABASE IF EXISTS test_lf4yt5w2 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:15:50.707959 [ 11749 ] {6413b61d-46f7-4a1a-8e55-8f0bec946a88} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:51.064917 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:51.087351 [ 3467 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:51.310738 [ 6836 ] {2af02cc3-814c-4708-957c-c23533b08a0d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54240) (comment: 02530_dictionaries_update_field.sh) (in query: DROP DICTIONARY dict_complex_key_hashed_custom), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:51.317745 [ 6836 ] {2af02cc3-814c-4708-957c-c23533b08a0d} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:15:51.511343 [ 6986 ] {75de1b2e-8e8e-47ca-8fbb-5cf03a04c298} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_11.a INNER JOIN (SELECT b AS j, b AS bb FROM test_11.b) USING (j). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03107_ill_formed_select_in_materialized_view.sql) (in query: /* ddl_entry=query-0000000103 */ CREATE MATERIALIZED VIEW test_11.view_4 UUID 'c72f6d31-b1f6-47a1-b3cb-a32a7672447d' TO INNER UUID 'eaa950a9-c945-4bfe-b476-68a3cb09ee06' (`bb` UInt64, `cnt` UInt64) ENGINE = MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM test_11.a INNER JOIN (SELECT b AS j, b AS bb FROM test_11.b) USING (j)) GROUP BY bb), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000011066c4b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110635e3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584eb4 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000011584d62 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647943 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f821f 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 18. /build/src/Interpreters/InterpreterInsertQuery.h:20: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x0000000011560d4a 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1488: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115587e0 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 24. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 25. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 26. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 28. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 29. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:15:51.541878 [ 6986 ] {75de1b2e-8e8e-47ca-8fbb-5cf03a04c298} executeQuery: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_11.a INNER JOIN (SELECT b AS j, b AS bb FROM test_11.b) USING (j). (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54184) (comment: 03107_ill_formed_select_in_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW view_4 ( bb UInt64, cnt UInt64) Engine=MergeTree ORDER BY bb POPULATE AS SELECT bb, count() AS cnt FROM (SELECT a, b AS j, b AS bb FROM a INNER JOIN (SELECT b AS j, b AS bb FROM b ) USING (j)) GROUP BY bb;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000011066c4b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110635e3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584eb4 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000011584d62 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647943 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f821f 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 18. /build/src/Interpreters/InterpreterInsertQuery.h:20: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x0000000011560d4a 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1488: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115587e0 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 24. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 25. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 26. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 28. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 29. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:15:51.546101 [ 6986 ] {75de1b2e-8e8e-47ca-8fbb-5cf03a04c298} TCPHandler: Code: 47. DB::Exception: JOIN INNER JOIN ... USING (j) using identifier 'j' cannot be resolved from left table expression. In scope SELECT a, b AS j, b AS bb FROM test_11.a INNER JOIN (SELECT b AS j, b AS bb FROM test_11.b) USING (j). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x0000000011066c4b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110635e3 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 12. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000011584eb4 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000011584d62 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647943 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f821f 17. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 18. /build/src/Interpreters/InterpreterInsertQuery.h:20: DB::InterpreterCreateQuery::fillTableIfNeeded(DB::ASTCreateQuery const&) @ 0x0000000011560d4a 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1488: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115587e0 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 21. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 24. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 25. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 26. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 28. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 29. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 30. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 2025.06.25 16:15:51.983002 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:52.137951 [ 3394 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:52.237642 [ 6379 ] {32ca7a8a-0b34-46de-9b6d-0332d713e316} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54084) (comment: 00578_merge_table_and_table_virtual_column.sql) (in query: SELECT count() FROM merge(currentDatabase(), '^numbers\\d+$') WHERE _table = 'non_existing';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:15:52.243672 [ 6379 ] {32ca7a8a-0b34-46de-9b6d-0332d713e316} TCPHandler: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:15:52.997452 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:53.153787 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:53.389847 [ 6986 ] {64c1c28b-f96b-4410-8604-08241b8e8aa9} executeQuery: Code: 57. DB::Exception: Table test_11.table1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00926_geo_to_h3.sql) (in query: /* ddl_entry=query-0000000106 */ CREATE TABLE test_11.table1 UUID '475bf229-f4b9-4192-94ea-c81d3aaf4a2b' (`lat` Float64, `lon` Float64, `resolution` UInt8) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:53.412143 [ 6986 ] {64c1c28b-f96b-4410-8604-08241b8e8aa9} executeQuery: Code: 57. DB::Exception: Table test_11.table1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54296) (comment: 00926_geo_to_h3.sql) (in query: CREATE TABLE table1 (lat Float64, lon Float64, resolution UInt8) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:53.414641 [ 6986 ] {64c1c28b-f96b-4410-8604-08241b8e8aa9} TCPHandler: Code: 57. DB::Exception: Table test_11.table1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:15:53.697168 [ 3419 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:53.798000 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:53.818069 [ 4197 ] {d160146a-4c71-4549-88d7-91143b53b5a6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54254) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:53.821226 [ 4197 ] {d160146a-4c71-4549-88d7-91143b53b5a6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:53.919297 [ 6986 ] {44b469d0-30bf-4bda-bb35-700763cf21ae} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57820) (comment: 00458_merge_type_cast.sql) (in query: DROP DATABASE IF EXISTS test_pnjwxf4v ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:15:53.921373 [ 6986 ] {44b469d0-30bf-4bda-bb35-700763cf21ae} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:54.158877 [ 3406 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:54.738527 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:55.165716 [ 3030 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:55.197531 [ 2956 ] {080a7635-b37d-4d6a-946a-9a024dc61860} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't2.value'. In scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54320) (comment: 02481_analyzer_join_alias_unknown_identifier_crash.sql) (in query: SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:15:55.200013 [ 2956 ] {080a7635-b37d-4d6a-946a-9a024dc61860} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't2.value'. In scope SELECT toTypeName(t2_value), t2.value AS t2_value FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 USING (id). Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:15:55.567978 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:56.183617 [ 3480 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:56.373176 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:56.841255 [ 2956 ] {5d266d47-b32f-4402-b452-d339f5a77801} OptimizeRegularExpression: Analyze RegularExpression failed, got error: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7f585f800000, frame address: 0x7f585fbfffe0, stack size: 4194336, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:57.186328 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:57.188089 [ 3244 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:57.965748 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:58.193002 [ 3442 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:58.195312 [ 2956 ] {5d266d47-b32f-4402-b452-d339f5a77801} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47408) (comment: 02831_regexp_analyze_recursion.sql) (in query: SELECT match('', repeat('(', 100000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/src/Functions/Regexps.h:0: std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000a0caee2 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0c84e1 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:15:58.241521 [ 2956 ] {5d266d47-b32f-4402-b452-d339f5a77801} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((, error: missing ): ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT match('', repeat('(', 100000)). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/src/Functions/Regexps.h:0: std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000a0caee2 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a0c84e1 7. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 8. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 18. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 24. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 25. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:15:58.670758 [ 4197 ] {53696437-57f3-42e0-98f6-c64e5056d8cd} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47486) (comment: 02125_query_views_log_window_function.sql) (in query: set enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:58.677625 [ 4197 ] {53696437-57f3-42e0-98f6-c64e5056d8cd} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:58.728069 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:15:59.197492 [ 3093 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:15:59.614602 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:00.199640 [ 3030 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:00.531767 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:00.790360 [ 6985 ] {d4f0052c-6f9d-4389-bb9d-5773268dc54c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47426) (comment: 02504_regexp_dictionary_table_source.sql) (in query: select * from needle_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:00.795137 [ 6985 ] {d4f0052c-6f9d-4389-bb9d-5773268dc54c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:01.203584 [ 3503 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:01.428976 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:01.549097 [ 2956 ] {8dd2707c-b4ee-4c1b-9a00-ecd05bff9a9b} executeQuery: Code: 57. DB::Exception: Table test_11.polygons already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00500_point_in_polygon_non_const_poly.sql) (in query: /* ddl_entry=query-0000000112 */ CREATE TABLE test_11.polygons UUID '1b33049c-5f39-4151-8927-c67c337a8556' (`id` Int32, `pt` Tuple(Int32, Int32), `poly` Array(Tuple(Int32, Int32))) ENGINE = Log), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:01.651607 [ 2956 ] {8dd2707c-b4ee-4c1b-9a00-ecd05bff9a9b} executeQuery: Code: 57. DB::Exception: Table test_11.polygons already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47518) (comment: 00500_point_in_polygon_non_const_poly.sql) (in query: create table polygons ( id Int32, pt Tuple(Int32, Int32), poly Array(Tuple(Int32, Int32))) engine = Log();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:01.656311 [ 2956 ] {8dd2707c-b4ee-4c1b-9a00-ecd05bff9a9b} TCPHandler: Code: 57. DB::Exception: Table test_11.polygons already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:02.207968 [ 3166 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:02.234124 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:03.025235 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:03.025963 [ 4197 ] {104428a8-fd2a-4686-b6a3-0fea5bf28242} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:47576). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47576) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:03.031122 [ 4197 ] {104428a8-fd2a-4686-b6a3-0fea5bf28242} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:47576). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:03.034210 [ 4197 ] {104428a8-fd2a-4686-b6a3-0fea5bf28242} TCPHandler: Client has gone away. 2025.06.25 16:16:03.212269 [ 3276 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:03.676083 [ 5054 ] {a84e10f0-6856-4012-9b43-9ffca42aca90} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_tar.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_x0njai5k.`02661_archive_table` UUID '133bc68e-f32b-4cfe-83a0-24dc05ffb695' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive{1..2}.tar :: 02661_read_from_archive_test_x0njai5k_tar_data1.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:03.706028 [ 5054 ] {a84e10f0-6856-4012-9b43-9ffca42aca90} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47652) (comment: 02661_read_from_archive_tar.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive{1..2}.tar :: 02661_read_from_archive_test_x0njai5k_tar_data1.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:03.719510 [ 5054 ] {a84e10f0-6856-4012-9b43-9ffca42aca90} TCPHandler: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:03.820336 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:04.218195 [ 3256 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:04.464769 [ 6155 ] {c33b2ec2-2388-4a72-b995-e6d743603899} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47674) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : tru}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000c6b115c 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d6696a 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:04.469387 [ 6155 ] {c33b2ec2-2388-4a72-b995-e6d743603899} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000c6b115c 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d6696a 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:04.638489 [ 6155 ] {e80314b0-87da-4b72-bef7-cd28c64f206e} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47674) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : fals}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000c6b115c 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d66bc0 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:04.649931 [ 6155 ] {e80314b0-87da-4b72-bef7-cd28c64f206e} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000c6b115c 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d66bc0 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:04.670485 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:04.759206 [ 6155 ] {7c691ea9-d90a-4fb3-be52-bca2e78cde2e} executeQuery: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47674) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : atru}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/IO/ReadHelpers.cpp:0: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000000c6c57b1 5. /build/src/IO/ReadHelpers.cpp:0: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x000000000c6b4114 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d66a9a 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:04.767255 [ 6155 ] {7c691ea9-d90a-4fb3-be52-bca2e78cde2e} TCPHandler: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/IO/ReadHelpers.cpp:0: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000000c6c57b1 5. /build/src/IO/ReadHelpers.cpp:0: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x000000000c6b4114 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010d66a9a 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000010d285cb 8. /build/src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x0000000012e59342 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b275 10. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:163: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x0000000012e6b515 11. /build/src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:235: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012e6b92b 12. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 13. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 14. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 15. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 17. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 18. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 19. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 20. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 21. /build/src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a1ee8 22. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 23. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 2025.06.25 16:16:05.222485 [ 3340 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:05.286543 [ 5174 ] {98434e22-84f9-4e48-9db5-1bb99f339111} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:47680). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47680) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:05.293643 [ 5174 ] {98434e22-84f9-4e48-9db5-1bb99f339111} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:47680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:05.296547 [ 5174 ] {98434e22-84f9-4e48-9db5-1bb99f339111} TCPHandler: Client has gone away. 2025.06.25 16:16:05.498872 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:06.231364 [ 3420 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:06.290869 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:06.322797 [ 6398 ] {055cbc45-f581-4e5e-b987-9a3d0d62da1c} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_tar.sh) (in query: /* ddl_entry=query-0000000006 */ CREATE TABLE test_x0njai5k.`02661_archive_table` UUID '490efb3f-afda-4233-8d52-5846cbc05778' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive{1,2}.tar :: 02661_read_from_archive_test_x0njai5k_tar_data{1,3}.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:06.348646 [ 6398 ] {055cbc45-f581-4e5e-b987-9a3d0d62da1c} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32874) (comment: 02661_read_from_archive_tar.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive{1,2}.tar :: 02661_read_from_archive_test_x0njai5k_tar_data{1,3}.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:06.448401 [ 6398 ] {055cbc45-f581-4e5e-b987-9a3d0d62da1c} TCPHandler: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:06.717468 [ 6665 ] {0c562d36-cd8d-4bda-a05d-dc8a4ccbf40d} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:32848). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32848) (comment: 02003_memory_limit_in_client.sh) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:06.720855 [ 6665 ] {0c562d36-cd8d-4bda-a05d-dc8a4ccbf40d} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:32848). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::WriteBuffer::nextIfAtEnd() @ 0x000000000702667d 5. /build/src/IO/WriteBuffer.h:93: DB::WriteBuffer::write(char const*, unsigned long) @ 0x00000000070268a8 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf28b 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x0000000010cdf4a6 8. /build/src/Formats/NativeWriter.cpp:76: DB::NativeWriter::write(DB::Block const&) @ 0x0000000012d27125 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc14f3 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 11. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:06.724497 [ 6665 ] {0c562d36-cd8d-4bda-a05d-dc8a4ccbf40d} TCPHandler: Client has gone away. 2025.06.25 16:16:07.236307 [ 3243 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:07.265946 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:08.021823 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:08.240891 [ 3379 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:08.925451 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:09.245961 [ 3395 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:09.263023 [ 6398 ] {3ed00526-8c50-4564-b1b9-69a9aef1f894} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_tar.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_x0njai5k.`02661_archive_table` UUID '77b7f198-157d-4240-a80d-4ceecc9c958d' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive3.tar :: 02661_read_from_archive_test_x0njai5k_tar_data*.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:09.297578 [ 6398 ] {3ed00526-8c50-4564-b1b9-69a9aef1f894} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33006) (comment: 02661_read_from_archive_tar.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive3.tar :: 02661_read_from_archive_test_x0njai5k_tar_data*.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:09.307426 [ 6398 ] {3ed00526-8c50-4564-b1b9-69a9aef1f894} TCPHandler: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:09.692329 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:10.248064 [ 3451 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:10.567355 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:11.252577 [ 3127 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:11.355998 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:11.835695 [ 5054 ] {ad361990-6e91-45a3-b531-6560c2d2349b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/f55/f5543d4e-410f-48ab-b7e5-73e102c35307/946796405_15_15_0/ in table test_13.test_sequenceNextNode_Nullable (f5543d4e-410f-48ab-b7e5-73e102c35307) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32828) (comment: 01656_sequence_next_node_long.sql) (in query: SELECT '(forward, head, A)', id, sequenceNextNode('forward', 'head')(dt, action, 1, action = 'A') AS next_node FROM test_sequenceNextNode_Nullable GROUP BY id ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3409f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:16:11.848277 [ 6398 ] {de2df4f0-278c-487c-91f4-c540e6f5661f} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_tar.sh) (in query: /* ddl_entry=query-0000000010 */ CREATE TABLE test_x0njai5k.`02661_archive_table` UUID 'eec2f82c-b82a-4000-b2ef-d6fc8f7ffadc' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive*.tar :: *.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:11.866112 [ 5054 ] {ad361990-6e91-45a3-b531-6560c2d2349b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/f55/f5543d4e-410f-48ab-b7e5-73e102c35307/946796405_15_15_0/ in table test_13.test_sequenceNextNode_Nullable (f5543d4e-410f-48ab-b7e5-73e102c35307) 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3409f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 2025.06.25 16:16:11.897672 [ 6398 ] {de2df4f0-278c-487c-91f4-c540e6f5661f} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33054) (comment: 02661_read_from_archive_tar.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive*.tar :: *.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:11.916208 [ 6398 ] {de2df4f0-278c-487c-91f4-c540e6f5661f} TCPHandler: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:12.202317 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:12.254108 [ 3480 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:12.405036 [ 6398 ] {54f4e6b3-8d8b-4413-ac1e-de6c114fe71f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33090) (comment: 02661_read_from_archive_tar.sh) (in query: SELECT * FROM 02661_archive_table ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:12.409991 [ 6398 ] {54f4e6b3-8d8b-4413-ac1e-de6c114fe71f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:13.057057 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:13.258847 [ 3152 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:13.987246 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:14.084483 [ 6398 ] {71b87fea-a541-483c-bb22-07906d1ee44b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33124) (comment: 02480_analyzer_alias_nullptr.sql) (in query: SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:16:14.087255 [ 6398 ] {71b87fea-a541-483c-bb22-07906d1ee44b} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x'. In scope SELECT min(b), x AS b FROM (SELECT max(number) FROM numbers(1)). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x0000000011064bab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046727 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046d01 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:16:14.263269 [ 3249 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:14.837046 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:15.098373 [ 6398 ] {f9743e18-3df3-4910-988d-1e7de75558f2} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_tar.sh) (in query: /* ddl_entry=query-0000000012 */ CREATE TABLE test_x0njai5k.`02661_archive_table` UUID '14693b00-7818-498f-851e-4d2ff679f6da' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive*.tar :: 02661_read_from_archive_test_x0njai5k_tar_data{2..3}.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:15.210744 [ 6398 ] {f9743e18-3df3-4910-988d-1e7de75558f2} executeQuery: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48978) (comment: 02661_read_from_archive_tar.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_x0njai5k_tar_archive*.tar :: 02661_read_from_archive_test_x0njai5k_tar_data{2..3}.csv')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:15.229225 [ 6398 ] {f9743e18-3df3-4910-988d-1e7de75558f2} TCPHandler: Code: 57. DB::Exception: Table test_x0njai5k.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:15.268727 [ 3330 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:15.753847 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:16.270521 [ 3244 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:16.722046 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:17.277008 [ 3404 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:17.534025 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:17.751429 [ 5056 ] {037990dd-fe9e-4c17-abf8-c34aacef68df} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37766) (comment: 02661_read_from_archive_tar.sh) (in query: DROP DATABASE IF EXISTS test_x0njai5k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:17.830507 [ 5056 ] {037990dd-fe9e-4c17-abf8-c34aacef68df} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:18.281714 [ 3172 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:18.363235 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:19.294402 [ 3126 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:19.307544 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:20.196910 [ 2952 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:20.300045 [ 3307 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:21.127840 [ 4191 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:21.305634 [ 3023 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:21.492539 [ 5056 ] {7e1aff48-5acb-40f7-8d0c-c24c4a15a002} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49060) (comment: 02983_const_sharding_key.sql) (in query: DROP DATABASE shard_0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:21.497156 [ 5056 ] {7e1aff48-5acb-40f7-8d0c-c24c4a15a002} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:22.022736 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:22.081649 [ 6398 ] {1dbf8106-a55f-4ea6-ac4d-2fd3e0795c16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49026) (comment: 00804_test_custom_compression_codes_log_storages.sql) (in query: SELECT count(*) FROM compression_codec_multiple_tiny_log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:22.084523 [ 6398 ] {1dbf8106-a55f-4ea6-ac4d-2fd3e0795c16} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:22.310693 [ 3051 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:22.545190 [ 3671 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f5543d4e-410f-48ab-b7e5-73e102c35307::lambda}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001279aba3 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000012798bc0 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::clearOldPartsFromFilesystem(bool) @ 0x0000000012798a39 11. /build/src/Storages/StorageMergeTree.cpp:1478: bool std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012a9ded5 12. /build/src/Storages/MergeTree/IExecutableTask.h:70: DB::ExecutableLambdaAdapter::executeStep() @ 0x000000001245c5b2 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012770b68 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000127714a2 15. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 16. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 17. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:22.766683 [ 5056 ] {7ae1c889-9cf2-4720-a069-52c3cef6d1e5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49124) (comment: 02983_const_sharding_key.sql) (in query: DROP DATABASE IF EXISTS shard_0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:22.823401 [ 5056 ] {7ae1c889-9cf2-4720-a069-52c3cef6d1e5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:22.880630 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:23.175344 [ 6398 ] {f7327c95-08a3-45ed-bfa4-4df1c0b20cc4} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = foo.b. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49144) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = foo.b;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:23.176763 [ 6398 ] {f7327c95-08a3-45ed-bfa4-4df1c0b20cc4} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = foo.b. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:23.293770 [ 6398 ] {7663cdc9-d39b-449a-a731-891919f34dd0} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = bar.b. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49144) (comment: 01478_not_equi-join_on.sql) (in query: SELECT * FROM (SELECT NULL AS a, 1 AS b) AS foo RIGHT JOIN (SELECT 1024 AS b) AS bar ON 1 = bar.b;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:23.303043 [ 6398 ] {7663cdc9-d39b-449a-a731-891919f34dd0} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in RIGHT JOIN ... ON 1 = bar.b. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:23.319508 [ 3468 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:23.611587 [ 6398 ] {08375f56-7798-43a7-ad39-2a84284aea44} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49148) (comment: 02983_const_sharding_key.sql) (in query: DROP DATABASE IF EXISTS shard_0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:23.620406 [ 6398 ] {08375f56-7798-43a7-ad39-2a84284aea44} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:23.814222 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:23.868469 [ 5056 ] {64c5c3f2-90f1-4971-b9c0-a4e46fc33750} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49160) (comment: 02514_bad_index_granularity.sql) (in query: CREATE TABLE t (`id` Int64, `d` String, `p` Map(String, String)) ENGINE = ReplacingMergeTree ORDER BY id SETTINGS index_granularity = 0, min_bytes_for_wide_part = 0, 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 = 536870912, compact_parts_max_bytes_to_buffer = 40034520, compact_parts_max_granules_to_buffer = 98, compact_parts_merge_max_bytes_to_prefetch_part = 30063883, merge_max_block_size = 7505, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5430896, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 9683, primary_key_compress_block_size = 44690), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:23.871732 [ 5056 ] {64c5c3f2-90f1-4971-b9c0-a4e46fc33750} TCPHandler: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:24.101027 [ 6155 ] {73855df4-c816-42d8-a543-3650c0b83dc0} executeQuery: Code: 57. DB::Exception: Table test_11.arrays_test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00909_arrayEnumerateUniq.sql) (in query: /* ddl_entry=query-0000000118 */ CREATE TABLE test_11.arrays_test UUID '068a31a0-2417-467b-b3bd-98f5ee53de59' (`a3` Array(Array(UInt8)), `a4` Array(Array(UInt32))) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:24.137060 [ 6155 ] {73855df4-c816-42d8-a543-3650c0b83dc0} executeQuery: Code: 57. DB::Exception: Table test_11.arrays_test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32958) (comment: 00909_arrayEnumerateUniq.sql) (in query: CREATE TABLE arrays_test (a3 Array(Array(UInt8)), a4 Array(Array(UInt32)) ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:24.145563 [ 6155 ] {73855df4-c816-42d8-a543-3650c0b83dc0} TCPHandler: Code: 57. DB::Exception: Table test_11.arrays_test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:24.323099 [ 3178 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:24.564297 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:24.694299 [ 5056 ] {f5908c1e-3e52-4058-8a6f-259b3c36daef} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58988) (comment: 02983_const_sharding_key.sql) (in query: DROP DATABASE IF EXISTS shard_0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:24.725003 [ 5056 ] {f5908c1e-3e52-4058-8a6f-259b3c36daef} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:25.327723 [ 3233 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:25.398680 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:25.968704 [ 6836 ] {79f18af3-fce0-4a7b-b0b7-b7ef527e7b0c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59038) (comment: 01710_aggregate_projections.sh) (in query: select x + y, sum(x - y) as s from test_agg_proj group by x + y order by s desc limit 5 settings optimize_use_projections=1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011519dee 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000115162f0 9. /build/src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x000000001152432f 10. /build/contrib/llvm-project/libcxx/include/__mutex_base:203: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000011523c45 11. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000011525842 12. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:16:25.993182 [ 6836 ] {79f18af3-fce0-4a7b-b0b7-b7ef527e7b0c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000011519dee 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000115162f0 9. /build/src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x000000001152432f 10. /build/contrib/llvm-project/libcxx/include/__mutex_base:203: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000011523c45 11. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000011525842 12. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:16:26.226754 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:26.332500 [ 3185 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:26.516618 [ 6836 ] {9112f64c-5160-4ace-b0c9-350b5eebe34d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39946) (comment: 01080_engine_merge_prewhere_tupleelement_error.sql) (in query: DROP DATABASE IF EXISTS test_nelpn4to ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:26.518912 [ 6836 ] {9112f64c-5160-4ace-b0c9-350b5eebe34d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:26.872653 [ 5190 ] {6cf276e9-961d-44be-a017-361da090906e} ExternalDictionariesLoader: Could not load external dictionary '9a5602fe-455a-4841-9bfd-5a87e9a3e65d', next update is scheduled at 2025-06-25 16:16:32: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/147/14716ff3-5667-4a6d-8a09-6e55fda2108e/all_1_1_0/ in table test_11.test_01051_d (14716ff3-5667-4a6d-8a09-6e55fda2108e) 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3001f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 30. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 31. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:26.880299 [ 6986 ] {6cf276e9-961d-44be-a017-361da090906e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/147/14716ff3-5667-4a6d-8a09-6e55fda2108e/all_1_1_0/ in table test_11.test_01051_d (14716ff3-5667-4a6d-8a09-6e55fda2108e) 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 dictGet(concat('test_11', '.test_dict_01051_d'), 'value', toUInt64(4)). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58992) (comment: 01050_clickhouse_dict_source_with_subquery.sql) (in query: SELECT dictGet(concat('test_11', '.test_dict_01051_d'), 'value', toUInt64(4))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3001f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 30. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 31. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 2025.06.25 16:16:26.948734 [ 6986 ] {6cf276e9-961d-44be-a017-361da090906e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/147/14716ff3-5667-4a6d-8a09-6e55fda2108e/all_1_1_0/ in table test_11.test_01051_d (14716ff3-5667-4a6d-8a09-6e55fda2108e) 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 dictGet(concat('test_11', '.test_dict_01051_d'), 'value', toUInt64(4)). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d3001f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 30. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 31. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 2025.06.25 16:16:27.166895 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:27.420548 [ 3412 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:27.916779 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:28.426067 [ 3100 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:28.836334 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:28.925777 [ 6986 ] {4c50f1d8-9113-4f36-9fdd-554f1054db9e} executeQuery: Code: 57. DB::Exception: Table test_11.nested_map already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00146_summing_merge_tree_nested_map.sql) (in query: /* ddl_entry=query-0000000123 */ CREATE TABLE test_11.nested_map UUID '13a3a239-465c-4a8c-ba70-8e69cd25f022' (`d` Date DEFAULT today(), `k` UInt64, `payload` UInt32 DEFAULT rand(), `SomeMap.ID` Array(String), `SomeMap.Num` Array(Int64)) ENGINE = SummingMergeTree(d, k, 8192)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:28.956715 [ 6836 ] {28eeb75c-d33e-459c-9c41-dd64defe3e89} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59146) (comment: 00825_protobuf_format_skipped_column_in_nested.sh) (in query: SELECT * FROM table_skipped_column_in_nested_00825 FORMAT Protobuf SETTINGS format_schema = '/usr/share/clickhouse-test/queries/0_stateless/format_schemas/00825_protobuf_format_skipped_column_in_nested:UpdateMessage'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d23b7e 14. /build/src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d70708 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddf71 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d23b7e 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddf71 18. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 20. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 21. /build/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&) @ 0x000000001282dc54 22. /build/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 @ 0x000000001282aa0e 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 25. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:16:28.962584 [ 6836 ] {28eeb75c-d33e-459c-9c41-dd64defe3e89} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d23b7e 14. /build/src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d70708 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddf71 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d23b7e 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cddf71 18. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 20. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 21. /build/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&) @ 0x000000001282dc54 22. /build/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 @ 0x000000001282aa0e 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 25. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:16:29.029224 [ 6986 ] {4c50f1d8-9113-4f36-9fdd-554f1054db9e} executeQuery: Code: 57. DB::Exception: Table test_11.nested_map already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59090) (comment: 00146_summing_merge_tree_nested_map.sql) (in query: create table nested_map (d default today(), k UInt64, payload default rand(), SomeMap Nested(ID String, Num Int64)) engine=SummingMergeTree(d, k, 8192);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:29.033623 [ 6986 ] {4c50f1d8-9113-4f36-9fdd-554f1054db9e} TCPHandler: Code: 57. DB::Exception: Table test_11.nested_map already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:29.083383 [ 4197 ] {dd5136db-0919-429f-810f-e95befcefc6d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59164) (comment: 01710_aggregate_projections.sh) (in query: select x + y + 1, argMax(x, y) * 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:29.099074 [ 4197 ] {dd5136db-0919-429f-810f-e95befcefc6d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:29.428985 [ 3192 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:29.643905 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:29.738904 [ 6836 ] {da9eb2cd-1adf-4836-a456-77f024660464} 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.10505.altinitytest (altinity build)) (from [::1]:59168) (comment: 01710_aggregate_projections.sh) (in query: select x + y + 1, argMax(x, y) * 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 format JSON), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:16:29.743541 [ 6836 ] {da9eb2cd-1adf-4836-a456-77f024660464} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:16:30.067257 [ 6986 ] {2f23d95a-ed84-4959-b8d0-2c226d32fd54} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59196) (comment: 00976_max_execution_speed.sql) (in query: SELECT count() FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:30.070664 [ 6986 ] {2f23d95a-ed84-4959-b8d0-2c226d32fd54} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:30.434332 [ 3007 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:30.434738 [ 4197 ] {424d7116-29c6-4ba4-bf32-c67e19ad3a6d} executeQuery: Code: 16. DB::Exception: No such column arr.key in table test_11.t (81051ac3-295a-4679-8b94-9a4a50cd91d9). (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59208) (comment: 02514_if_with_lazy_low_cardinality.sql) (in query: insert into t (`arr.key`, `arr.value`) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x00000000115f59c2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000115f4eff 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8b8 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:30.518860 [ 4197 ] {424d7116-29c6-4ba4-bf32-c67e19ad3a6d} TCPHandler: Code: 16. DB::Exception: No such column arr.key in table test_11.t (81051ac3-295a-4679-8b94-9a4a50cd91d9). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x00000000115f59c2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000115f4eff 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb8b8 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:30.570298 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:31.196706 [ 2956 ] {c91fdaa8-4418-4e27-8050-b6f8651626a1} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope (SELECT toDecimal128([], rowNumberInBlock())). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59266) (comment: 00811_garbage.sql) (in query: SELECT ( SELECT toDecimal128([], rowNumberInBlock()) ) , lcm('', [[(CAST(('>A') AS String))]]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:547: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000073142e1 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000007306bbb 8. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 9. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 10. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:16:31.209301 [ 2956 ] {c91fdaa8-4418-4e27-8050-b6f8651626a1} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope (SELECT toDecimal128([], rowNumberInBlock())). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: 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&&) @ 0x00000000070320f9 4. /build/src/Functions/FunctionHelpers.cpp:0: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000703042a 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000702fe3b 6. /build/contrib/llvm-project/libcxx/include/vector:547: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl>>, DB::(anonymous namespace)::NameToDecimal128, DB::(anonymous namespace)::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x00000000073142e1 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000007306bbb 8. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 9. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 10. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 15. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:16:31.489840 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:31.528547 [ 3188 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:31.931320 [ 2956 ] {13b1ae58-1f76-4cb1-af28-99ee5a27210a} executeQuery: Code: 57. DB::Exception: Table test_11.t0 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03268_empty_tuple_update.sql) (in query: /* ddl_entry=query-0000000126 */ CREATE TABLE test_11.t0 UUID '83f3f7a2-2fc3-4653-a0ee-57f84d42d4af' (`c0` Tuple, `c1` Int32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:32.009089 [ 2956 ] {13b1ae58-1f76-4cb1-af28-99ee5a27210a} executeQuery: Code: 57. DB::Exception: Table test_11.t0 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59274) (comment: 03268_empty_tuple_update.sql) (in query: CREATE TABLE t0 (c0 Tuple(), c1 int) ENGINE = Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:32.012951 [ 2956 ] {13b1ae58-1f76-4cb1-af28-99ee5a27210a} TCPHandler: Code: 57. DB::Exception: Table test_11.t0 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:32.431483 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:32.532883 [ 3328 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:32.585889 [ 6985 ] {386b5745-d1cc-4ed1-8d13-f3407ebe45b1} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:16:32.588155 [ 6985 ] {386b5745-d1cc-4ed1-8d13-f3407ebe45b1} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59292) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00732/quorum_lost_alive', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 56223, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5773977637290955, replace_long_file_name_to_hash = false, max_file_name_length = 104, min_bytes_for_full_part_storage = 48558465, compact_parts_max_bytes_to_buffer = 195548771, compact_parts_max_granules_to_buffer = 51, compact_parts_merge_max_bytes_to_prefetch_part = 16632864, merge_max_block_size = 19068, 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 = 10737418240, index_granularity_bytes = 30137670, concurrent_part_removal_threshold = 72, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 71191, primary_key_compress_block_size = 80575), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:32.601813 [ 6985 ] {386b5745-d1cc-4ed1-8d13-f3407ebe45b1} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:32.990337 [ 2956 ] {68978729-aca3-4901-a490-556e75ced7b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40014) (comment: 01715_tuple_insert_null_as_default.sql) (in query: DROP DATABASE IF EXISTS test_c738gog6 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:32.991730 [ 2956 ] {68978729-aca3-4901-a490-556e75ced7b1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:33.344334 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:33.539867 [ 3207 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:34.212693 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:34.217950 [ 4197 ] {4cfec482-8736-401d-b0b6-7b110264f700} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Tuple(Date, String), Tuple(String)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59252) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000087ef314 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:34.220750 [ 4197 ] {4cfec482-8736-401d-b0b6-7b110264f700} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Tuple(Date, String), Tuple(String)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (log_date, value) = tuple('2021-01-01'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000087ef314 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:34.303056 [ 4197 ] {f8efd083-da51-4a90-82f8-637072795db1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Tuple(UInt32, String), Tuple(UInt8)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59252) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000087ef314 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:34.309273 [ 4197 ] {f8efd083-da51-4a90-82f8-637072795db1} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Tuple(UInt32, String), Tuple(UInt8)) of function equals: In scope SELECT * FROM test_tuple_filter WHERE (id, value) = tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000087ef314 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:34.511260 [ 4197 ] {03eba5b3-31ee-4958-b77b-81b65203f709} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt32, String because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59252) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE tuple(id, value) = tuple(value, id);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:528: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc869c 6. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000008807932 7. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ed56d 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 14. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 15. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 16. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 17. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000011625f58 18. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654c69 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e915 20. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 21. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 22. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:16:34.514019 [ 4197 ] {03eba5b3-31ee-4958-b77b-81b65203f709} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt32, String because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:528: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc869c 6. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x0000000008807932 7. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ed56d 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 14. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 15. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 16. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 17. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000011625f58 18. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654c69 19. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164e915 20. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 21. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 22. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:16:34.544178 [ 3438 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:34.721458 [ 4197 ] {7612f9ac-32db-4170-8b3a-024b4e1b30a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT * FROM test_tuple_filter WHERE equals((id, value)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59252) (comment: 02030_tuple_filter.sql) (in query: SELECT * FROM test_tuple_filter WHERE equals((id, value));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:16:34.724713 [ 4197 ] {7612f9ac-32db-4170-8b3a-024b4e1b30a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT * FROM test_tuple_filter WHERE equals((id, value)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:16:35.085885 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:35.549446 [ 3297 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:36.008132 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:36.553330 [ 3252 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:36.925544 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:37.558246 [ 3359 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:37.818782 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:38.562911 [ 3105 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:38.677278 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:39.061065 [ 2956 ] {70257d1d-1b72-4c02-8433-c1ff0e5cd2b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/5f4/5f48790a-7294-4d1a-898b-d10fdc5b3c75/all_1_3_1/ in table test_z5yzhl9v.test (5f48790a-7294-4d1a-898b-d10fdc5b3c75) located on disk default of type local, from mark 0 with max_rows_to_read = 60912): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59052) (comment: 03037_dynamic_merges_2_vertical_wide_merge_tree.sql) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128beac2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bdbac 18. /build/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()() @ 0x00000000128bfb84 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c1a3f 20. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 22. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:16:39.078561 [ 2956 ] {70257d1d-1b72-4c02-8433-c1ff0e5cd2b7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/5f4/5f48790a-7294-4d1a-898b-d10fdc5b3c75/all_1_3_1/ in table test_z5yzhl9v.test (5f48790a-7294-4d1a-898b-d10fdc5b3c75) located on disk default of type local, from mark 0 with max_rows_to_read = 60912): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128beac2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bdbac 18. /build/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()() @ 0x00000000128bfb84 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c1a3f 20. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 22. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:16:39.250092 [ 4197 ] {f057867a-462b-4754-99d9-a80c3faacb61} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42792) (comment: 03037_dynamic_merges_2_vertical_wide_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_z5yzhl9v ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:39.254175 [ 4197 ] {f057867a-462b-4754-99d9-a80c3faacb61} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:39.318753 [ 5174 ] {0e9e14ec-4a3d-4f59-8ff9-2910a32baeb0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42794) (comment: 03037_dynamic_merges_2_vertical_wide_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_z5yzhl9v ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:39.337213 [ 5174 ] {0e9e14ec-4a3d-4f59-8ff9-2910a32baeb0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:39.462625 [ 6665 ] {0af59f91-d1ae-4f87-bd0c-ac27b8e65441} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42808) (comment: 03037_dynamic_merges_2_vertical_wide_merge_tree.sql) (in query: DROP DATABASE IF EXISTS test_z5yzhl9v ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:39.469244 [ 6665 ] {0af59f91-d1ae-4f87-bd0c-ac27b8e65441} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:39.545281 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:39.572736 [ 3358 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:40.094632 [ 5054 ] {e83a793a-599d-43d8-9fea-92a284cf50c4} executeQuery: Code: 264. DB::Exception: Table test_13.left_join__fuzz_2 (50fb4da8-e2ac-4ebd-8368-333a555086ec) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59216) (comment: 03095_join_filter_push_down_right_stream_filled.sql) (in query: SELECT 14 FROM t1__fuzz_0 LEFT JOIN left_join__fuzz_2 USING (x) WHERE pointInPolygon(materialize((-inf, 1023)), [(5, 0.9998999834060669), (1.1920928955078125e-7, 100.0000991821289), (1.000100016593933, 100.0000991821289)]) ORDER BY toNullable('202.79.32.10') DESC NULLS LAST, toNullable(toLowCardinality(toUInt256(14))) ASC, x DESC NULLS LAST;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000012293f25 5. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011684fe7 6. /build/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&) @ 0x000000001166e306 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:40.104992 [ 5054 ] {e83a793a-599d-43d8-9fea-92a284cf50c4} TCPHandler: Code: 264. DB::Exception: Table test_13.left_join__fuzz_2 (50fb4da8-e2ac-4ebd-8368-333a555086ec) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/StorageJoin.cpp:0: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x0000000012293f25 5. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011684fe7 6. /build/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&) @ 0x000000001166e306 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:16:40.267004 [ 6985 ] {44c5987d-c8e2-4511-9a0f-90326f56a8f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59138) (comment: 00829_bitmap64_function.sql) (in query: SELECT count(*) FROM bitmap_test WHERE 0 = bitmapHasAny((SELECT groupBitmapState(uid) FROM bitmap_test WHERE pickup_date = '2019-01-01'), bitmapBuild([uid]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011040e7a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103960f 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:16:40.279095 [ 6985 ] {44c5987d-c8e2-4511-9a0f-90326f56a8f9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011040e7a 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103960f 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110329ba 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:16:40.330046 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:40.542003 [ 6985 ] {27976157-e609-4f93-a079-065403d384f3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42832) (comment: 00829_bitmap64_function.sql) (in query: DROP DATABASE IF EXISTS test_0j9oi5ih ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:40.550446 [ 6985 ] {27976157-e609-4f93-a079-065403d384f3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:40.577621 [ 3282 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:40.734213 [ 5054 ] {33f150ac-f89c-46ed-a907-7fa2dae9a8c3} DatabaseReplicated (test_ell69cgh): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:16:40.743508 [ 5054 ] {33f150ac-f89c-46ed-a907-7fa2dae9a8c3} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59264) (comment: 01513_count_without_select_sequence_consistency_zookeeper_long.sql) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01513/sequence_consistency', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 15065, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 24, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 446308440, compact_parts_max_granules_to_buffer = 132, compact_parts_merge_max_bytes_to_prefetch_part = 25803077, merge_max_block_size = 21569, old_parts_lifetime = 456., 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 = 13771425, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 41441, primary_key_compress_block_size = 26828), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:40.756886 [ 5054 ] {33f150ac-f89c-46ed-a907-7fa2dae9a8c3} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:41.193075 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:41.583845 [ 3425 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:41.968476 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:42.661901 [ 3518 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:42.800638 [ 4197 ] {25daeec9-cf20-4697-9647-99b321fd31a6} StorageBuffer (test_13.buffer_00753): Destination table test_13.dst_00753 have different type of column y (String != UInt64). Block of data is converted. 2025.06.25 16:16:42.801878 [ 4197 ] {25daeec9-cf20-4697-9647-99b321fd31a6} StorageBuffer (test_13.buffer_00753): Not all columns from block in buffer exist in destination table test_13.dst_00753. Some columns are discarded. 2025.06.25 16:16:42.803790 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:43.641938 [ 4197 ] {468b45ba-ef40-4547-ab26-2cfc37bfe4a5} StorageBuffer (test_13.buffer_00753): Destination table test_13.dst_00753 doesn't have column x. The default values are used. 2025.06.25 16:16:43.642460 [ 4197 ] {468b45ba-ef40-4547-ab26-2cfc37bfe4a5} StorageBuffer (test_13.buffer_00753): Destination table test_13.dst_00753 has different type of column y (String != UInt64). Data from destination table are converted. 2025.06.25 16:16:43.663193 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:43.669483 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:43.901203 [ 4197 ] {635e7683-9e14-4464-af2a-c6c04cb452b4} StorageBuffer (test_13.buffer_00753): Destination table test_13.dst_00753 have different type of column y (String != UInt64). Block of data is converted. 2025.06.25 16:16:43.902116 [ 4197 ] {635e7683-9e14-4464-af2a-c6c04cb452b4} StorageBuffer (test_13.buffer_00753): Not all columns from block in buffer exist in destination table test_13.dst_00753. Some columns are discarded. 2025.06.25 16:16:44.350130 [ 4197 ] {6960903f-f81a-47c6-8f6e-a5a9e88408bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59272) (comment: 00753_alter_destination_for_storage_buffer.sql) (in query: SELECT * FROM dst_00753 ORDER BY y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:44.361041 [ 4197 ] {6960903f-f81a-47c6-8f6e-a5a9e88408bb} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:16:44.590468 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:44.692440 [ 3419 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:45.354867 [ 5174 ] {e45277a2-f4ab-4214-883d-cfdf99a4541e} executeQuery: Code: 57. DB::Exception: Table test_ks7m65m2.log already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59402) (comment: 00299_stripe_log_multiple_inserts.sql) (in query: CREATE TABLE log (x UInt8) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:45.367242 [ 5174 ] {e45277a2-f4ab-4214-883d-cfdf99a4541e} TCPHandler: Code: 57. DB::Exception: Table test_ks7m65m2.log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:45.616203 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:45.697360 [ 3390 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:46.494176 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:46.712691 [ 3295 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:47.511508 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:47.816406 [ 3025 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:48.060816 [ 5174 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:48.352880 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:48.821862 [ 3217 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:48.989562 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:48.990578 [ 6155 ] {050efaeb-3ef7-49d2-bbf6-7d4014aa756a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51818) (comment: 02241_array_first_last_or_null.sql) (in query: SELECT 'ArrayLast with Null';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:49.007177 [ 6155 ] {050efaeb-3ef7-49d2-bbf6-7d4014aa756a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:49.297107 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:49.306695 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:49.671736 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:49.830320 [ 3519 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:50.065495 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:50.310509 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:50.392992 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:50.819245 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:50.838858 [ 3301 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:51.280236 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:51.343672 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:51.683606 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:51.843581 [ 3184 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:52.024288 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:52.213554 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:52.335361 [ 8172 ] {ea483ede-d496-49cd-a270-241d54a960cc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57806) (comment: 00578_merge_table_and_table_virtual_column.sql) (in query: DROP DATABASE IF EXISTS test_6zjfdn7f ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:52.337566 [ 8172 ] {ea483ede-d496-49cd-a270-241d54a960cc} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:52.361743 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:52.734022 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:52.861284 [ 3108 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:53.021294 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:53.138269 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:53.260110 [ 11749 ] {56d177ab-371d-49b9-9f6c-a69b4238f26a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52048) (comment: 01825_type_json_10.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:53.266096 [ 11749 ] {56d177ab-371d-49b9-9f6c-a69b4238f26a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:53.332212 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:53.355182 [ 3627 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {aea16b08-61a9-4255-9e00-8afbf0fac250::202506_1_53_10}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:53.866448 [ 3434 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:54.096535 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:54.868749 [ 3188 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:55.128459 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:55.784168 [ 6665 ] {60284492-faef-41c2-8479-f7ee4d277205} executeQuery: Code: 57. DB::Exception: Table test_13.decimal already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51780) (comment: 01798_uniq_theta_sketch.sql) (in query: CREATE TABLE decimal ( a Decimal32(4), b Decimal64(8), c Decimal128(8) ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:55.801403 [ 6665 ] {60284492-faef-41c2-8479-f7ee4d277205} TCPHandler: Code: 57. DB::Exception: Table test_13.decimal already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:55.873927 [ 3476 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:56.079356 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:56.565245 [ 11749 ] {2d9d0443-89c4-484d-be8f-f9aa4cc5cafc} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56580) (comment: 01635_sum_map_fuzz.sql) (in query: SELECT [NULL], sumMapWithOverflow(events, [NULL], [[(NULL)]], counts) FROM sum_map_overflow;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: 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*) @ 0x000000000f9c3267 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:56.567310 [ 11749 ] {2d9d0443-89c4-484d-be8f-f9aa4cc5cafc} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/AggregateFunctions/AggregateFunctionSumMap.cpp:0: 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*) @ 0x000000000f9c3267 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:56.660174 [ 5056 ] {9956820a-380e-4eaf-a33c-a0dca1189287} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56596) (comment: 03161_cnf_reduction.sql) (in query: EXPLAIN SYNTAX SELECT id FROM 03161_table WHERE f AND (NOT(f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x000000001160d3d9 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116076e7 11. /build/contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116070cc 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011606e31 13. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157f2bb 14. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f570 15. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 16. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157980e 18. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:56.664750 [ 5056 ] {9956820a-380e-4eaf-a33c-a0dca1189287} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000116a3e23 9. /build/src/Interpreters/InterpreterSetQuery.h:14: DB::InterpreterSelectQuery::initSettings() @ 0x000000001160d3d9 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116076e7 11. /build/contrib/llvm-project/libcxx/include/optional:260: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116070cc 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011606e31 13. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001157f2bb 14. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f570 15. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 16. /build/src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000001157f57b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157980e 18. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:16:56.875476 [ 3141 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:56.924238 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:56.980545 [ 5056 ] {4f30752a-9b53-4306-976a-f3124017dd54} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37124) (comment: 00717_low_cardinaliry_distributed_group_by.sql) (in query: DROP DATABASE IF EXISTS test_hf6737at ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:57.003156 [ 5056 ] {4f30752a-9b53-4306-976a-f3124017dd54} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:57.589499 [ 5056 ] {523537b5-71da-4275-8cfd-7c4f26593763} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56624) (comment: 02499_monotonicity_toUnixTimestamp64.sh) (in query: create table t(ts DateTime64) engine=MergeTree order by ts as select * from numbers_mt(1e6);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:57.608187 [ 5056 ] {523537b5-71da-4275-8cfd-7c4f26593763} TCPHandler: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:16:57.807045 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:57.850398 [ 2956 ] {test_13_02499_2206928036} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ts' in scope SELECT ts FROM t ORDER BY toUnixTimestamp64Nano(ts) ASC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56668) (comment: 02499_monotonicity_toUnixTimestamp64.sh) (in query: select ts from t order by toUnixTimestamp64Nano(ts) limit 10 format Null settings max_block_size = 8192, optimize_read_in_order = 1, max_threads = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:57.861417 [ 2956 ] {test_13_02499_2206928036} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ts' in scope SELECT ts FROM t ORDER BY toUnixTimestamp64Nano(ts) ASC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:16:57.890195 [ 3336 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:58.731173 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:58.912218 [ 3426 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:59.124682 [ 6986 ] {9e43402b-fd3b-4834-ab23-8ad009d589c7} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56656) (comment: 02907_clickhouse_dictionary_bug.sh) (in query: DROP DICTIONARY 02907_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:59.136180 [ 6986 ] {9e43402b-fd3b-4834-ab23-8ad009d589c7} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:16:59.383679 [ 6836 ] {211944e9-45fc-435d-9d91-e8deac9bd19e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37158) (comment: 02907_clickhouse_dictionary_bug.sh) (in query: DROP DATABASE IF EXISTS test_rdxm62n3 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:16:59.387343 [ 6836 ] {211944e9-45fc-435d-9d91-e8deac9bd19e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:16:59.544740 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:16:59.917458 [ 3120 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:00.303025 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:00.922730 [ 3333 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:01.186389 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:01.928352 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:02.208610 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:02.862861 [ 6836 ] {f856e981-b5b2-4d76-85f1-5c8b3df37968} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56840) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere x != 0 where arr;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000011082baa 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x00000000110827f5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033899 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:17:02.867027 [ 6836 ] {f856e981-b5b2-4d76-85f1-5c8b3df37968} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE x != 0 WHERE arr. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000011082baa 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x00000000110827f5 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033899 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:17:02.933532 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:03.045498 [ 6836 ] {49e828ca-78f1-4d39-9be0-df2c412b00ae} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56840) (comment: 01674_where_prewhere_array_crash.sql) (in query: select x from tab array join arr prewhere arr where x != 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000011082baa 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x000000001108274d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033899 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:17:03.045696 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:03.053462 [ 6836 ] {49e828ca-78f1-4d39-9be0-df2c412b00ae} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: Tuple(a UInt64, b UInt64). In query SELECT x FROM tab ARRAY JOIN arr PREWHERE arr WHERE x != 0. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000011082baa 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::validateFilters(std::shared_ptr const&) @ 0x000000001108274d 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5603: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000011033899 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 13. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:17:03.190530 [ 4197 ] {5358295e-d4d6-4784-997c-801f8604dc55} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37228) (comment: 01674_where_prewhere_array_crash.sql) (in query: DROP DATABASE IF EXISTS test_848yy0nc ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:03.192958 [ 4197 ] {5358295e-d4d6-4784-997c-801f8604dc55} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:03.232563 [ 6836 ] {d9285e05-fd76-427b-b9b8-fde19893fe44} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37244) (comment: 01674_where_prewhere_array_crash.sql) (in query: DROP DATABASE IF EXISTS test_848yy0nc ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:03.235964 [ 6836 ] {d9285e05-fd76-427b-b9b8-fde19893fe44} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:03.302249 [ 2956 ] {6d4da1a0-d012-40f5-ad81-243c27d4bd82} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56814) (comment: 01018_ambiguous_column.sql) (in query: SELECT dummy FROM one JOIN one AS A ON A.dummy = one.dummy;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:03.305736 [ 2956 ] {6d4da1a0-d012-40f5-ad81-243c27d4bd82} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:03.870498 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:03.937472 [ 3423 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:04.766275 [ 6836 ] {d2f59ee8-d8d3-45a1-984b-e797756092cf} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56866) (comment: 02411_merge_tree_zero_max_read_buffer_size.sql) (in query: SELECT * FROM data_02411 FORMAT Null SETTINGS max_read_buffer_size=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x000000001110b7ab 4. /build/src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x000000001110129e 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001318031a 6. /build/contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001285be3c 7. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x00000000128497b4 8. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001284957e 9. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000012a783cf 10. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 11. /build/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&) @ 0x000000001166245c 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 14. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 15. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:04.768742 [ 6836 ] {d2f59ee8-d8d3-45a1-984b-e797756092cf} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x000000001110b7ab 4. /build/src/Interpreters/Context.cpp:5561: DB::Context::getReadSettings() const @ 0x000000001110129e 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:148: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000001318031a 6. /build/contrib/llvm-project/libcxx/include/optional:260: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000001285be3c 7. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x00000000128497b4 8. /build/src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000001284957e 9. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000012a783cf 10. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 11. /build/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&) @ 0x000000001166245c 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 13. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 14. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 15. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:04.855421 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:04.943097 [ 3239 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:05.835122 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:05.945440 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:06.697415 [ 4197 ] {8d4f1d94-8876-4d90-a312-4958727a37bf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37950) (comment: 00538_datediff_plural_units.sql) (in query: SELECT dateDiff('years', toDate('2017-12-31'), toDate('2016-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:06.721184 [ 4197 ] {8d4f1d94-8876-4d90-a312-4958727a37bf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:06.791611 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:06.947615 [ 4197 ] {ba6b1543-773a-40f9-bc3c-61b56beb8d80} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55838) (comment: 01014_count_of_merges_metrics.sql) (in query: DROP DATABASE IF EXISTS test_mzrw79e3 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:06.949893 [ 3300 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:06.949955 [ 4197 ] {ba6b1543-773a-40f9-bc3c-61b56beb8d80} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:07.050014 [ 6665 ] {57e61631-88d9-4e2e-b878-39cb0e57bbaf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55856) (comment: 01014_count_of_merges_metrics.sql) (in query: DROP DATABASE IF EXISTS test_mzrw79e3 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:07.054492 [ 6665 ] {57e61631-88d9-4e2e-b878-39cb0e57bbaf} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:07.952275 [ 3215 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:08.256145 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:08.956760 [ 3232 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.181481 [ 3716 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001117124f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159d52 9. /build/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&) @ 0x0000000010dfbcaa 10. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.217627 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:09.319310 [ 6398 ] {f290617f-d917-47af-be08-0733ecd4a1e2} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_hhc810e3' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001117124f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159d52 9. /build/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&) @ 0x0000000010dfbcaa 10. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55870) (comment: 02500_remove_redundant_distinct.sh) (in query: CREATE DATABASE IF NOT EXISTS test_hhc810e3 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000c817d26 5. /build/src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000c7ee65e 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b2f4 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:09.321762 [ 6398 ] {f290617f-d917-47af-be08-0733ecd4a1e2} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_hhc810e3' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001117124f 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::startup() @ 0x0000000011159d52 9. /build/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&) @ 0x0000000010dfbcaa 10. /build/contrib/llvm-project/libcxx/include/exception:185: DB::AsyncLoader::worker(DB::AsyncLoader::Pool&) @ 0x000000000c81b1d3 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10505.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000c817d26 5. /build/src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000c7ee65e 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b2f4 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.461318 [ 6836 ] {a2c9ab89-867a-4107-99c4-d4c035db6635} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:dfd27a3a-1154-42c9-a9d0-b424f2a67735'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55886) (comment: 02513_prewhere_combine_step_filters.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gky85qkl ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:09.472211 [ 6836 ] {a2c9ab89-867a-4107-99c4-d4c035db6635} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:dfd27a3a-1154-42c9-a9d0-b424f2a67735'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.566534 [ 8172 ] {95865262-8272-441e-a7b5-966cc90ee8d4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:955dc38a-2b13-4556-aaa9-578281260ded'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55894) (comment: 01451_dist_logs.sh) (in query: CREATE DATABASE IF NOT EXISTS test_9g4gzdkv ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:09.576138 [ 8172 ] {95865262-8272-441e-a7b5-966cc90ee8d4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:955dc38a-2b13-4556-aaa9-578281260ded'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.640114 [ 6836 ] {026f89a2-7034-44e0-96d6-2030d9743ae6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:59b14e03-65c6-44b3-bef4-d414de429422'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55896) (comment: 01068_window_view_event_tumble_to_bounded_lateness.sh) (in query: CREATE DATABASE IF NOT EXISTS test_t5b88wpk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:09.654495 [ 6836 ] {026f89a2-7034-44e0-96d6-2030d9743ae6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:59b14e03-65c6-44b3-bef4-d414de429422'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.774937 [ 8172 ] {0571dbec-1974-42d6-85d3-6a5b28d10e61} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:c6f5a020-4583-4380-965d-d4cd0d65ad04'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55908) (comment: 02301_harmful_reexec.sh) (in query: CREATE DATABASE IF NOT EXISTS test_bxdwhtra ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:09.807317 [ 8172 ] {0571dbec-1974-42d6-85d3-6a5b28d10e61} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:c6f5a020-4583-4380-965d-d4cd0d65ad04'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.958784 [ 3381 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:09.967239 [ 8172 ] {a0113841-cd01-4ac4-b252-d7ffd59267bb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:1f1e6ede-0427-4bb3-ba52-6c05875ad9d7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55914) (comment: 02336_sparse_columns_s3.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0o5nvvms ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:09.978230 [ 8172 ] {a0113841-cd01-4ac4-b252-d7ffd59267bb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:1f1e6ede-0427-4bb3-ba52-6c05875ad9d7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.140854 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:10.096563 [ 6836 ] {3a131c89-c776-4a36-9af6-a94a865ab039} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:11ae9d48-5f36-4a6d-aac7-28d62a2166be'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55924) (comment: 02152_bool_type_parsing.sh) (in query: CREATE DATABASE IF NOT EXISTS test_s2agc1rx ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.146039 [ 6836 ] {3a131c89-c776-4a36-9af6-a94a865ab039} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:11ae9d48-5f36-4a6d-aac7-28d62a2166be'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.208491 [ 11749 ] {db2b9e7a-8757-4c18-8805-76a78ccc303b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:bc3addfd-610e-4a0f-be7c-cc7a9f3e39bb'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55926) (comment: 02523_array_shuffle.sql) (in query: CREATE DATABASE IF NOT EXISTS test_b31w2asf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.213294 [ 11749 ] {db2b9e7a-8757-4c18-8805-76a78ccc303b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:bc3addfd-610e-4a0f-be7c-cc7a9f3e39bb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.229053 [ 4197 ] {4388607c-e80f-4ee3-bcd7-2f4e325734a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37976) (comment: 02494_query_cache_asynchronous_metrics.sql) (in query: SELECT value FROM system.asynchronous_metrics WHERE metric = 'QueryCacheEntries';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:10.234305 [ 4197 ] {4388607c-e80f-4ee3-bcd7-2f4e325734a0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:10.354832 [ 6836 ] {03a5579e-5ac4-4082-bc22-561f648eb09e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:4eef7e7f-7945-42ae-b780-9d1436fc0e9a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55930) (comment: 02812_bug_with_unused_join_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_uvsy3v7v ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.359648 [ 6836 ] {03a5579e-5ac4-4082-bc22-561f648eb09e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:4eef7e7f-7945-42ae-b780-9d1436fc0e9a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.474854 [ 4197 ] {84b725b2-c6fb-43e3-bb86-91a1ebd42a4b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:c37b628a-32f5-4017-a92a-a0466cd24f88'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55934) (comment: 00805_round_down.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x6lx6gn0 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.477521 [ 4197 ] {84b725b2-c6fb-43e3-bb86-91a1ebd42a4b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:c37b628a-32f5-4017-a92a-a0466cd24f88'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.776286 [ 6836 ] {b7a027ad-2182-422e-be0b-aa1ce98c8f1d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:7569fdf6-9cc8-4650-a3ba-ad742ab4930b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55938) (comment: 01316_create_user_syntax_hilite.sh) (in query: CREATE DATABASE IF NOT EXISTS test_b0rij5nv ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.782914 [ 6836 ] {b7a027ad-2182-422e-be0b-aa1ce98c8f1d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:7569fdf6-9cc8-4650-a3ba-ad742ab4930b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.910538 [ 6836 ] {010df204-de28-402e-bf32-b050a1e3584c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:80ef57f4-aaa7-405b-b30d-2d60a8d04848'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55942) (comment: 01906_lc_in_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2wbo3n8p ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:10.914420 [ 6836 ] {010df204-de28-402e-bf32-b050a1e3584c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:80ef57f4-aaa7-405b-b30d-2d60a8d04848'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:10.949410 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:10.963774 [ 3210 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.055525 [ 11749 ] {185fc7c4-42b3-487e-af06-8e6186735390} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:573548cf-9f09-44b9-94b7-917c70a3c79a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55944) (comment: 02429_combinators_in_array_reduce.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fzu5oj4h ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.057977 [ 11749 ] {185fc7c4-42b3-487e-af06-8e6186735390} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:573548cf-9f09-44b9-94b7-917c70a3c79a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.291583 [ 6836 ] {973bf5b0-3140-4e33-8e0f-5064f4643fbe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:acc1e13b-c1ec-4900-881b-d9f63d0b0113'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55952) (comment: 02735_capnp_case_insensitive_names_matching.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5mhbsa1q ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.294786 [ 6836 ] {973bf5b0-3140-4e33-8e0f-5064f4643fbe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:acc1e13b-c1ec-4900-881b-d9f63d0b0113'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.506083 [ 6836 ] {b3a6dbc8-e81f-49aa-a93b-d338ce1e1c04} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:b2bfd10d-16ea-4df9-99d0-4d1337d1a600'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55954) (comment: 01652_ttl_old_syntax.sql) (in query: CREATE DATABASE IF NOT EXISTS test_chrg7312 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.508004 [ 6836 ] {b3a6dbc8-e81f-49aa-a93b-d338ce1e1c04} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:b2bfd10d-16ea-4df9-99d0-4d1337d1a600'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.589241 [ 6836 ] {760cdebe-808a-419e-8b44-d59107bb1ee7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:4730e2c0-b98e-48a2-842a-e0aa02a21e8e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55958) (comment: 00309_formats.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tzeqz73r ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.593895 [ 6836 ] {760cdebe-808a-419e-8b44-d59107bb1ee7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:4730e2c0-b98e-48a2-842a-e0aa02a21e8e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.645696 [ 4197 ] {d3bb907b-efe0-410e-b530-5b41c393f057} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 4.14 MiB (attempt to allocate chunk of 1050816 bytes), maximum: 3.81 MiB.: while executing 'FUNCTION repeat('aa'_String :: 1, __table1.number :: 2) -> repeat('aa'_String, __table1.number) String : 0'. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38022) (comment: 01656_test_query_log_factories_info.sql) (in query: SELECT repeat('aa', number) FROM numbers(10e3) SETTINGS max_memory_usage=4e6, max_block_size=100 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/Common/PODArray.h:120: void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000701b399 9. /build/src/Functions/repeat.cpp:0: auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000b574a56 10. /build/src/Functions/castTypeToEither.h:12: DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56cb5b 11. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 18. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:17:11.676675 [ 4197 ] {d3bb907b-efe0-410e-b530-5b41c393f057} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 4.14 MiB (attempt to allocate chunk of 1050816 bytes), maximum: 3.81 MiB.: while executing 'FUNCTION repeat('aa'_String :: 1, __table1.number :: 2) -> repeat('aa'_String, __table1.number) String : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000c66c449 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66bac9 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/Common/PODArray.h:120: void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000701b399 9. /build/src/Functions/repeat.cpp:0: auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000b574a56 10. /build/src/Functions/castTypeToEither.h:12: DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b56cb5b 11. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 18. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:17:11.693527 [ 8172 ] {6fdad5e8-9be5-49f1-b33f-18d7c1443a75} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:9476ec7c-f8c8-42b3-819f-a95227639dd7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55970) (comment: 00090_union_race_conditions_1.sh) (in query: CREATE DATABASE IF NOT EXISTS test_f0fhun1k ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.700784 [ 8172 ] {6fdad5e8-9be5-49f1-b33f-18d7c1443a75} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:9476ec7c-f8c8-42b3-819f-a95227639dd7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.787396 [ 6398 ] {4e28ff34-2838-4fb0-bb25-a6429b342656} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:ba079ee0-1659-4d29-881b-5b30c270ac5e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55976) (comment: 03096_largest_triangle_3b_crash.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0zl3tauw ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:11.805842 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:11.846303 [ 6398 ] {4e28ff34-2838-4fb0-bb25-a6429b342656} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '60383288ac7c:9000:88bb4fcb-78d3-48af-a635-f94ab84ff06a', current host ID: '60383288ac7c:9000:ba079ee0-1659-4d29-881b-5b30c270ac5e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:11.968496 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:12.665995 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:12.723689 [ 6398 ] {1408bca6-404d-4a3b-8019-4b952c7d5350} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55988) (comment: 01051_new_any_join_engine.sql) (in query: DROP DATABASE IF EXISTS test_i4onx0u0 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:12.727501 [ 6398 ] {1408bca6-404d-4a3b-8019-4b952c7d5350} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:12.989581 [ 3322 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:13.528436 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:13.991406 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:14.423344 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:15.047057 [ 3082 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:15.435591 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:15.680348 [ 5174 ] {1884c9b2-e121-4a2c-b163-18c4750556e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37994) (comment: 01395_limit_more_cases.sh) (in query: SELECT 0, 4, count() AS c, min(number) AS first, max(number) AS last, throwIf(first != (0 < 13 AND 4 > 0 ? 0 : 0)), throwIf(last != (0 < 13 AND 4 > 0 ? least(13 - 1, 0 + 4 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(13) LIMIT 0, 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:15.735316 [ 5174 ] {1884c9b2-e121-4a2c-b163-18c4750556e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:16.050012 [ 3263 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:16.246042 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:17.055054 [ 3137 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:17.264558 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:18.056706 [ 3106 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:18.115916 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:19.043177 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:19.058796 [ 3210 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:19.823302 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:19.996897 [ 6155 ] {2bc523b0-b1b5-472f-a0f6-cef2118d2caf} 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.10505.altinitytest (altinity build)) (from [::1]:48544) (comment: 01621_sort_after_join_pipeline_stuck.sql) (in query: SELECT k FROM (SELECT NULL, nullIf(number, 3) AS k, '1048575', (65536, -9223372036854775808), toString(number) AS a FROM system.numbers LIMIT 1048577) AS js1 ANY RIGHT JOIN (SELECT 1.000100016593933, nullIf(number, NULL) AS k, toString(number) AS b FROM system.numbers LIMIT 2, 255) AS js2 USING (k) ORDER BY 257 ASC NULLS LAST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:19.998703 [ 6398 ] {60039af7-54a4-430e-ad88-086292e09d38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38080) (comment: 01771_bloom_filter_not_has.sql) (in query: SELECT COUNT() FROM bloom_filter_null_array;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:17:20.016678 [ 6398 ] {60039af7-54a4-430e-ad88-086292e09d38} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:17:20.016912 [ 6155 ] {2bc523b0-b1b5-472f-a0f6-cef2118d2caf} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:17:20.156786 [ 3002 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:20.798504 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:21.159478 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:21.786547 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:22.164652 [ 3102 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:22.760790 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:23.170190 [ 3059 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:23.590701 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:23.902947 [ 3839 ] {02e197ed-4f16-42c4-84bd-7539fed4c13a} ExternalDictionariesLoader: Could not load external dictionary '1e4854f2-e350-4841-a22f-84753a7b517a', next update is scheduled at 2025-06-25 16:17:29: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:23.907238 [ 6155 ] {02e197ed-4f16-42c4-84bd-7539fed4c13a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48588) (comment: 01259_dictionary_custom_settings_ddl.sql) (in query: SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:23.912059 [ 6155 ] {02e197ed-4f16-42c4-84bd-7539fed4c13a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:24.070058 [ 6155 ] {81632c4d-0fe6-4bdb-9652-bb65ae25fb47} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48588) (comment: 01259_dictionary_custom_settings_ddl.sql) (in query: DROP DATABASE IF EXISTS ordinary_db;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:24.078515 [ 6155 ] {81632c4d-0fe6-4bdb-9652-bb65ae25fb47} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:24.175658 [ 3481 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:24.650991 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:25.181403 [ 3329 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:25.322608 [ 4197 ] {e1161c03-1dc7-466c-b265-2aeae59a9fec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column current_database): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_57_57_0/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 65): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38022) (comment: 01656_test_query_log_factories_info.sql) (in query: -- 1. analyzer includes arrayJoin into functions list -- 2. for crc32 (CaseInsensitive function) we use lower case now SELECT arraySort(arrayMap(x -> x == 'crc32' ? 'CRC32' : x, arrayFilter(x-> x != 'arrayJoin', used_functions))) as `arraySort(used_functions)` FROM system.query_log WHERE current_database = currentDatabase() AND type = 'QueryFinish' AND (query LIKE '%toDate(\'2000-12-05\')%') ORDER BY query_start_time DESC LIMIT 1 FORMAT TabSeparatedWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 17. /build/src/IO/ReadHelpers.h:0: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d19ced 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x00000000128dab90 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128da927 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efa8c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 25. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 26. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 27. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 28. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 29. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 30. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 31. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 2025.06.25 16:17:25.387353 [ 4197 ] {e1161c03-1dc7-466c-b265-2aeae59a9fec} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column current_database): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_57_57_0/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 65): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 17. /build/src/IO/ReadHelpers.h:0: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000010d19ced 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x00000000128dab90 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128da927 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efa8c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 25. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 26. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 27. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 28. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 29. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 30. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 31. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 2025.06.25 16:17:25.657410 [ 5054 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:26.161499 [ 11749 ] {f476dccc-2b04-4d86-a727-4aeaaf738366} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48482) (comment: 01395_limit_more_cases.sh) (in query: WITH count() AS c, min(number) AS first, max(number) AS last SELECT throwIf(first != (24 < 82 AND 67 > 0 ? 24 : 0)), throwIf(last != (24 < 82 AND 67 > 0 ? least(82 - 1, 24 + 67 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(82) LIMIT 24, 67);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:17:26.172755 [ 11749 ] {f476dccc-2b04-4d86-a727-4aeaaf738366} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:17:26.192267 [ 3152 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:26.197326 [ 5054 ] {06892248-c10b-4c30-970b-5bc9c21d65fd} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:17:26.210085 [ 5054 ] {06892248-c10b-4c30-970b-5bc9c21d65fd} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (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 = 57562, min_bytes_for_wide_part = 238744955, 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 = 200234865, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 305199, merge_max_block_size = 6207, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24119646, concurrent_part_removal_threshold = 42, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 71306, primary_key_compress_block_size = 45063), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:26.248365 [ 5054 ] {06892248-c10b-4c30-970b-5bc9c21d65fd} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:26.526614 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:27.195262 [ 3034 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:27.478819 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:28.030682 [ 6665 ] {72a10085-1e42-4d46-acb6-4c3a1ec015c2} executeQuery: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44086) (comment: 01036_union_different_columns.sql) (in query: select 1 as c1, 2 as c2, 3 as c3 union all (select 1 as c1, 2 as c2, 3 as c3 union all select 1 as c1, 2 as c2) -- { serverError UNION_ALL_RESULT_STRUCTURES_MISMATCH } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001100968b 4. /build/src/Planner/Utils.cpp:0: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x000000001100648e 5. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForUnionNode() @ 0x000000001164afcf 6. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a777 7. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 8. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:28.038349 [ 6665 ] {72a10085-1e42-4d46-acb6-4c3a1ec015c2} TCPHandler: Code: 258. DB::Exception: Different number of columns in UNION_ALL elements: c1, c2, c3 and c1, c2. (UNION_ALL_RESULT_STRUCTURES_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001100968b 4. /build/src/Planner/Utils.cpp:0: DB::buildCommonHeaderForUnion(std::vector> const&, DB::SelectUnionMode) @ 0x000000001100648e 5. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForUnionNode() @ 0x000000001164afcf 6. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a777 7. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 8. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:28.204362 [ 3244 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:28.360000 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:28.855264 [ 5056 ] {276d4cbf-3aa3-4547-9dab-704302caa3a0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44122) (comment: 01825_type_json_partitions.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:28.859226 [ 5056 ] {276d4cbf-3aa3-4547-9dab-704302caa3a0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:29.092531 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:29.218478 [ 3340 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:29.864793 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:30.221362 [ 3057 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:30.776909 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:31.226050 [ 3140 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:31.790529 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:32.230442 [ 3115 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:32.641653 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:33.234929 [ 3439 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:33.256881 [ 6665 ] {03523d93-7436-44a1-a307-8f5fa9d1f447} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44218) (comment: 02835_fuzz_remove_redundant_sorting.sql) (in query: CREATE TABLE numbers500k (`number` UInt32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 19179, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 238085918, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 11113193, merge_max_block_size = 14086, 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 = 736290442, index_granularity_bytes = 20407632, concurrent_part_removal_threshold = 95, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 84065, primary_key_compress_block_size = 68281), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:33.269226 [ 6665 ] {03523d93-7436-44a1-a307-8f5fa9d1f447} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:33.432313 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:34.239227 [ 3455 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:34.339351 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:35.134002 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:35.247018 [ 3268 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:35.554768 [ 4371 ] {14678be2-510d-4dad-8e1d-42a0404717da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56980) (comment: 02721_url_cluster.sql) (in query: SELECT __table1.c1 AS c1, __table1.c2 AS c2, __table1.c3 AS c3 FROM urlCluster('test_cluster_one_shard_three_replicas_localhost', 'http://localhost:11111/test/{a,b}.tsv', 'TSV', '`c1` Nullable(Int64), `c2` Nullable(Int64), `c3` Nullable(Int64)') AS __table1 ORDER BY __table1.c1 ASC, __table1.c2 ASC, __table1.c3 ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:35.559659 [ 4371 ] {14678be2-510d-4dad-8e1d-42a0404717da} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:35.589579 [ 6986 ] {68a8f37c-f6ae-4de8-800b-9bf832c2c659} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44058) (comment: 02721_url_cluster.sql) (in query: select * from urlCluster('test_cluster_one_shard_three_replicas_localhost', 'http://localhost:11111/test/{a,b}.tsv', 'auto') order by c1, c2, c3;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfce7f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fe03 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:17:35.595149 [ 6986 ] {68a8f37c-f6ae-4de8-800b-9bf832c2c659} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=741). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x0000000012bfce7f 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000010c1fe03 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:17:35.620249 [ 4370 ] {81b68fe8-cb30-4d3a-aaec-5220f8d0e4ec} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:33270). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33270) (comment: 02721_url_cluster.sql) (in query: SELECT __table1.c1 AS c1, __table1.c2 AS c2, __table1.c3 AS c3 FROM urlCluster('test_cluster_one_shard_three_replicas_localhost', 'http://localhost:11111/test/{a,b}.tsv', 'TSV', '`c1` Nullable(Int64), `c2` Nullable(Int64), `c3` Nullable(Int64)') AS __table1 ORDER BY __table1.c1 ASC, __table1.c2 ASC, __table1.c3 ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:35.624999 [ 4370 ] {81b68fe8-cb30-4d3a-aaec-5220f8d0e4ec} 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]:33270). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:35.626700 [ 4370 ] {81b68fe8-cb30-4d3a-aaec-5220f8d0e4ec} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:33270). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:35.631563 [ 4370 ] {81b68fe8-cb30-4d3a-aaec-5220f8d0e4ec} TCPHandler: Client has gone away. 2025.06.25 16:17:35.904057 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:36.284127 [ 3023 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:36.288918 [ 4197 ] {68ab2f71-f643-4095-a46c-f63ba2719df1} executeQuery: Code: 57. DB::Exception: Table test_11.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02525_range_hashed_dictionary_update_field.sql) (in query: /* ddl_entry=query-0000000139 */ CREATE TABLE test_11.test_table UUID '34c18e44-09ee-4af1-b8a7-f7ebdd1df554' (`uid` Int64, `start` Int64, `end` Int64, `insert_time` DateTime) ENGINE = MergeTree ORDER BY (uid, start) SETTINGS index_granularity = 33364, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.9667414426803589, replace_long_file_name_to_hash = false, max_file_name_length = 40, min_bytes_for_full_part_storage = 436973328, compact_parts_max_bytes_to_buffer = 226642289, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 33283569, merge_max_block_size = 15666, old_parts_lifetime = 256., 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 = 2388373406, index_granularity_bytes = 15002936, concurrent_part_removal_threshold = 45, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96033, primary_key_compress_block_size = 12846), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:36.455594 [ 4197 ] {68ab2f71-f643-4095-a46c-f63ba2719df1} executeQuery: Code: 57. DB::Exception: Table test_11.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59476) (comment: 02525_range_hashed_dictionary_update_field.sql) (in query: CREATE TABLE test_table (`uid` Int64, `start` Int64, `end` Int64, `insert_time` DateTime) ENGINE = MergeTree ORDER BY (uid, start) SETTINGS index_granularity = 33364, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.9667414426803589, replace_long_file_name_to_hash = false, max_file_name_length = 40, min_bytes_for_full_part_storage = 436973328, compact_parts_max_bytes_to_buffer = 226642289, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 33283569, merge_max_block_size = 15666, old_parts_lifetime = 256., 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 = 2388373406, index_granularity_bytes = 15002936, concurrent_part_removal_threshold = 45, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 96033, primary_key_compress_block_size = 12846), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:36.458344 [ 4197 ] {68ab2f71-f643-4095-a46c-f63ba2719df1} TCPHandler: Code: 57. DB::Exception: Table test_11.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:17:36.732126 [ 4371 ] {abc0158c-2ba6-47a8-b545-94113b22b0c0} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59590) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123dedeb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:36.766911 [ 4371 ] {abc0158c-2ba6-47a8-b545-94113b22b0c0} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123dedeb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:36.817674 [ 11749 ] {28a65973-900e-49ce-8a9d-8ef4ad5b26bf} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59612) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123dedeb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:36.829365 [ 11749 ] {28a65973-900e-49ce-8a9d-8ef4ad5b26bf} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123dedeb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:36.841108 [ 6985 ] {f6cf8bc0-fa19-4e7e-b125-ccdf49871211} executeQuery: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59606) (comment: 02998_operator_respect_nulls.sql) (in query: SELECT plus(1, 1) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x000000000c975acb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053070 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:37.005935 [ 4371 ] {25a4a17c-476a-4744-9aeb-d5fd8734f385} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59702) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.021933 [ 22667 ] {a79aafff-c5bb-413c-9f5d-cf8b2aa5f2d1} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59636) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.050568 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:37.121960 [ 22694 ] {cf3fed36-1c14-48d6-a929-f2f3cf20abd7} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59680) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.137426 [ 6985 ] {f6cf8bc0-fa19-4e7e-b125-ccdf49871211} TCPHandler: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x000000000c975acb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053070 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:37.141031 [ 4371 ] {25a4a17c-476a-4744-9aeb-d5fd8734f385} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.148146 [ 22667 ] {a79aafff-c5bb-413c-9f5d-cf8b2aa5f2d1} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.173139 [ 22694 ] {cf3fed36-1c14-48d6-a929-f2f3cf20abd7} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.287375 [ 3194 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:37.511542 [ 6665 ] {b6210dff-32c0-4071-90eb-4828a9581b86} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59816) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.525439 [ 6665 ] {b6210dff-32c0-4071-90eb-4828a9581b86} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.698765 [ 22699 ] {38515953-3b85-44f4-95f5-f61b3651cf12} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59870) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.780089 [ 22699 ] {38515953-3b85-44f4-95f5-f61b3651cf12} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.858340 [ 22699 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:37.934490 [ 22672 ] {8ae045a9-0055-4a99-a33d-8557e9f369ac} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59846) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.941364 [ 4371 ] {58a6a0b6-3e9b-45b7-acbb-b13710425743} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59806) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.943355 [ 22706 ] {613b49fe-74fc-474c-8234-0ffaa7cda974} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59778) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.941247 [ 22672 ] {8ae045a9-0055-4a99-a33d-8557e9f369ac} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.944584 [ 22706 ] {613b49fe-74fc-474c-8234-0ffaa7cda974} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.949052 [ 4371 ] {58a6a0b6-3e9b-45b7-acbb-b13710425743} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.969210 [ 22700 ] {651af368-48b4-484a-adda-2452e0e7b573} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59954) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:37.999502 [ 22700 ] {651af368-48b4-484a-adda-2452e0e7b573} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.182475 [ 6665 ] {c6a37ad7-d13b-40d4-8f07-522ef92e77c0} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60012) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.191334 [ 6665 ] {c6a37ad7-d13b-40d4-8f07-522ef92e77c0} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.212581 [ 22703 ] {32a31903-4b6d-4944-9812-719b725519fc} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60062) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.227421 [ 22703 ] {32a31903-4b6d-4944-9812-719b725519fc} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.239069 [ 22705 ] {6cf55986-4688-4ec7-b0c5-89728cf752e6} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60076) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.240827 [ 22706 ] {bdc5007c-1537-446e-9716-60e42c1a34c1} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60084) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.244014 [ 22706 ] {bdc5007c-1537-446e-9716-60e42c1a34c1} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.250747 [ 22705 ] {6cf55986-4688-4ec7-b0c5-89728cf752e6} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.288627 [ 3125 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:38.373862 [ 22711 ] {590da28f-b2fb-43ec-8b90-914d7526c80a} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60092) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.398350 [ 22711 ] {590da28f-b2fb-43ec-8b90-914d7526c80a} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.601466 [ 22703 ] {46d429d4-6076-4273-b40b-81735c021de1} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60122) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.603075 [ 22703 ] {46d429d4-6076-4273-b40b-81735c021de1} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.613108 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:38.629780 [ 22706 ] {cf1df245-36e8-4014-b6f3-dd9a3ef3bfbc} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60148) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.638553 [ 6665 ] {0bb212a7-40db-466b-9bdd-4f0ec550cae9} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60102) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.641324 [ 22706 ] {cf1df245-36e8-4014-b6f3-dd9a3ef3bfbc} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.653208 [ 6665 ] {0bb212a7-40db-466b-9bdd-4f0ec550cae9} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.813208 [ 11749 ] {b1912e57-2e1b-4588-a5cf-f34b94a89d5f} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60118) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.916507 [ 22706 ] {cfcbc681-ddd1-4080-8a79-1ca486ebdfa4} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60176) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.927698 [ 11749 ] {b1912e57-2e1b-4588-a5cf-f34b94a89d5f} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.949461 [ 22706 ] {cfcbc681-ddd1-4080-8a79-1ca486ebdfa4} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:38.991398 [ 22712 ] {f8eaf8c1-d14c-474f-9141-2cbcb85b0c72} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60190) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.001051 [ 22712 ] {f8eaf8c1-d14c-474f-9141-2cbcb85b0c72} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.003557 [ 6665 ] {4e3446e7-156c-4a71-84ed-8b5853fdbe52} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60200) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.011406 [ 6665 ] {4e3446e7-156c-4a71-84ed-8b5853fdbe52} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.017102 [ 22703 ] {fefa330e-8a60-4ab6-b418-424c91fc3b61} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60170) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.033114 [ 22703 ] {fefa330e-8a60-4ab6-b418-424c91fc3b61} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.234599 [ 22705 ] {e5eb4c88-aea9-4914-82bf-2ed3e01a7b95} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60228) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.264686 [ 4370 ] {321d7c42-25d8-47ae-ba43-900f86f6da2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59574) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:39.265917 [ 22705 ] {e5eb4c88-aea9-4914-82bf-2ed3e01a7b95} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.299738 [ 3378 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:39.320632 [ 22706 ] {56a8130b-354f-4592-95c0-ddf7ab9eb9a3} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60240) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.345616 [ 22706 ] {56a8130b-354f-4592-95c0-ddf7ab9eb9a3} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.358559 [ 4370 ] {321d7c42-25d8-47ae-ba43-900f86f6da2f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=734). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:39.394521 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:39.429934 [ 22703 ] {b8097554-70bf-4226-85c5-4ef00ace5dfa} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60212) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.449669 [ 22703 ] {b8097554-70bf-4226-85c5-4ef00ace5dfa} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.460736 [ 22712 ] {9325b8e7-e35e-43db-bd7a-12491ac6aa92} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60250) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.473036 [ 22712 ] {9325b8e7-e35e-43db-bd7a-12491ac6aa92} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.485792 [ 6665 ] {6a700088-07d1-4249-9891-564b07618869} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60254) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.505205 [ 6665 ] {6a700088-07d1-4249-9891-564b07618869} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.537913 [ 11749 ] {e272f635-3dee-4cc4-8378-62b6a6fdfa3c} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60268) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.549332 [ 11749 ] {e272f635-3dee-4cc4-8378-62b6a6fdfa3c} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.731335 [ 11749 ] {4fa2d170-fcdc-48c3-82d0-f0374bad32a9} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60298) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.756286 [ 11749 ] {4fa2d170-fcdc-48c3-82d0-f0374bad32a9} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.760551 [ 5082 ] {818e0e2b-f926-425a-b365-18c4ec9d4540} void DB::ParallelParsingInputFormat::onBackgroundException(): 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:39.791290 [ 6665 ] {db8b9303-88a1-4221-bc9f-9cb05ce03e60} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60324) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.858244 [ 6665 ] {db8b9303-88a1-4221-bc9f-9cb05ce03e60} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.867751 [ 22712 ] {be152b5e-14a1-4bab-9191-fc6a15d83eec} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60312) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.890123 [ 22712 ] {be152b5e-14a1-4bab-9191-fc6a15d83eec} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.908428 [ 22703 ] {818e0e2b-f926-425a-b365-18c4ec9d4540} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_table_function_file/2/test_2): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60278) (comment: 02105_table_function_file_partiotion_by.sh) (in query: select * from file('/var/lib/clickhouse/user_files/test_table_function_file/2/test_2', 'TSV', 'column1 UInt32, column2 UInt32, column3 UInt32')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:39.916817 [ 22703 ] {818e0e2b-f926-425a-b365-18c4ec9d4540} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_table_function_file/2/test_2): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:39.932545 [ 11749 ] {f6fe4374-b520-4959-b9c7-49bc3fb7fe77} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60336) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.935029 [ 6398 ] {8159a4a0-385a-48ef-80dc-7977e2ca8a21} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60330) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.953199 [ 11749 ] {f6fe4374-b520-4959-b9c7-49bc3fb7fe77} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:39.971068 [ 6398 ] {8159a4a0-385a-48ef-80dc-7977e2ca8a21} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.094726 [ 22712 ] {a19a4df4-7109-4f26-85ac-74eaafbd1239} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60376) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.116366 [ 22712 ] {a19a4df4-7109-4f26-85ac-74eaafbd1239} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.158817 [ 6986 ] {219afc07-22d3-4fea-84a1-af96afec0a31} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60402) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.160079 [ 22679 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:40.165352 [ 6986 ] {219afc07-22d3-4fea-84a1-af96afec0a31} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.304191 [ 3254 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:40.326032 [ 11749 ] {31f106a1-9994-4002-b8c9-01206d55219f} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60386) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.360559 [ 11749 ] {31f106a1-9994-4002-b8c9-01206d55219f} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.422459 [ 6986 ] {025bad2d-bc37-4b2b-8c2d-f3a52d5d1135} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60436) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.424190 [ 6986 ] {025bad2d-bc37-4b2b-8c2d-f3a52d5d1135} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.465799 [ 22701 ] {70574ded-26a4-4a75-aa2a-60dc85771669} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60446) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.476680 [ 22701 ] {70574ded-26a4-4a75-aa2a-60dc85771669} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.590521 [ 11749 ] {09f79489-29ee-4096-8061-a87fad7ecd28} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60450) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.613031 [ 11749 ] {09f79489-29ee-4096-8061-a87fad7ecd28} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.656289 [ 22679 ] {dbe3779d-839e-453d-9fea-ea2f568dbec7} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60442) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.665400 [ 22679 ] {dbe3779d-839e-453d-9fea-ea2f568dbec7} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.712314 [ 22701 ] {2ad52617-f140-44b7-9501-22f7087ddfe7} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60470) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.714202 [ 22701 ] {2ad52617-f140-44b7-9501-22f7087ddfe7} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.835364 [ 22679 ] {50233caf-619e-430a-8b27-e93095ec731f} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60486) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.841308 [ 22679 ] {50233caf-619e-430a-8b27-e93095ec731f} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.899420 [ 6986 ] {59424465-86bf-48bf-b115-69b127a1fa2c} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60468) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.908409 [ 6986 ] {59424465-86bf-48bf-b115-69b127a1fa2c} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.936629 [ 22701 ] {c9aeb160-8f64-4988-baee-990587b29fcd} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60500) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.941924 [ 22701 ] {c9aeb160-8f64-4988-baee-990587b29fcd} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:40.968286 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:41.030126 [ 6986 ] {c3a2b367-8780-4baf-a330-53cc64e5549f} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60522) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.037190 [ 6986 ] {c3a2b367-8780-4baf-a330-53cc64e5549f} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.101326 [ 22679 ] {fc8f0de7-490c-4c85-8c12-dbf559f579d3} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60508) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.122756 [ 22679 ] {fc8f0de7-490c-4c85-8c12-dbf559f579d3} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.168909 [ 6986 ] {7a454d58-711a-4ff1-9f89-ae92006791a4} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60526) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.181179 [ 6986 ] {7a454d58-711a-4ff1-9f89-ae92006791a4} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.309003 [ 3051 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:41.374108 [ 22679 ] {be1b2d77-645a-4a42-96af-b35b9cfa7c07} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60546) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.385740 [ 22679 ] {be1b2d77-645a-4a42-96af-b35b9cfa7c07} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.394124 [ 6986 ] {06a6eedc-1ba5-4d2d-b966-36b54a1c47f7} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60548) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.401528 [ 6986 ] {06a6eedc-1ba5-4d2d-b966-36b54a1c47f7} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.408841 [ 22712 ] {d2f7b49d-31de-4c20-b3b9-8838297f7228} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60562) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.469218 [ 22712 ] {d2f7b49d-31de-4c20-b3b9-8838297f7228} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.623071 [ 22700 ] {594c4283-c221-4ef2-8467-218cd5fdf17c} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60590) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.637031 [ 22700 ] {594c4283-c221-4ef2-8467-218cd5fdf17c} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.651022 [ 22712 ] {b7134d50-1791-4e7d-af17-337f5ebc2967} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60614) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.654532 [ 22712 ] {b7134d50-1791-4e7d-af17-337f5ebc2967} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.721622 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:41.741693 [ 11749 ] {2c598927-0b90-4253-b57f-76c8c36888b9} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60574) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.753071 [ 11749 ] {2c598927-0b90-4253-b57f-76c8c36888b9} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.798118 [ 22700 ] {2675b3a1-a028-46ef-b726-34a26377d33f} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60632) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.808971 [ 22700 ] {2675b3a1-a028-46ef-b726-34a26377d33f} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.811442 [ 22679 ] {7cbeb5aa-d8e9-409c-a58d-e12fb1002cb9} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60606) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.823844 [ 22679 ] {7cbeb5aa-d8e9-409c-a58d-e12fb1002cb9} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.873885 [ 6986 ] {535e1efe-6095-40a9-a4d1-00d0183bbbd6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60604) (comment: 00427_alter_primary_key.sh) (in query: CREATE TABLE alter_00427 (d Date, a Enum8('foo'=1), b DateTime, c DateTime) ENGINE=MergeTree(d, (a, b, toTime(c)), 8192)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:41.882394 [ 6986 ] {535e1efe-6095-40a9-a4d1-00d0183bbbd6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:41.938876 [ 22679 ] {5df6f5c3-f7f4-4a2d-ae8f-7dd20528e070} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60644) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:41.947006 [ 22679 ] {5df6f5c3-f7f4-4a2d-ae8f-7dd20528e070} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.023925 [ 6986 ] {3a385857-ba56-4601-b56b-5988da297cf1} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60650) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.033028 [ 6986 ] {3a385857-ba56-4601-b56b-5988da297cf1} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.173302 [ 11749 ] {3413ce79-3ebd-4208-8c22-b951a588e7c1} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60654) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.199611 [ 11749 ] {3413ce79-3ebd-4208-8c22-b951a588e7c1} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.213916 [ 6986 ] {d2d2b7b5-e266-4460-96c3-3ec9ca50dfa2} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60660) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.231405 [ 6986 ] {d2d2b7b5-e266-4460-96c3-3ec9ca50dfa2} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.256987 [ 22679 ] {2fa9fbc6-42f3-4008-839f-2199e2f7af5e} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60688) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.264191 [ 22679 ] {2fa9fbc6-42f3-4008-839f-2199e2f7af5e} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.271266 [ 22700 ] {87f98ea4-70be-4f06-9b20-b43fe66f343d} executeQuery: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60684) (comment: 00427_alter_primary_key.sh) (in query: INSERT INTO alter_00427 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:42.279360 [ 22700 ] {87f98ea4-70be-4f06-9b20-b43fe66f343d} TCPHandler: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:42.292150 [ 22712 ] {9acb500c-a5b9-4752-8da3-d49a9a7f6b52} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60674) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.318326 [ 3131 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:42.321645 [ 22712 ] {9acb500c-a5b9-4752-8da3-d49a9a7f6b52} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.484497 [ 6986 ] {a83d0d44-41b5-4809-ae75-4dc6a6d0ba02} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60700) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.486206 [ 6986 ] {a83d0d44-41b5-4809-ae75-4dc6a6d0ba02} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.518043 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:42.549844 [ 22705 ] {493f3eeb-06d5-4a43-9195-85e89d0633a2} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60756) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.558191 [ 22679 ] {9b519082-5dd5-4738-b15c-25a6753ae13c} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60754) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.559085 [ 22705 ] {493f3eeb-06d5-4a43-9195-85e89d0633a2} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.565093 [ 22679 ] {9b519082-5dd5-4738-b15c-25a6753ae13c} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.600629 [ 6986 ] {c9d70678-d0c7-4e24-82fe-3a56fe3878dd} executeQuery: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60772) (comment: 00427_alter_primary_key.sh) (in query: ALTER TABLE alter_00427 MODIFY COLUMN d UInt16), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:42.605649 [ 6986 ] {c9d70678-d0c7-4e24-82fe-3a56fe3878dd} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:42.699881 [ 22712 ] {67e4ff33-85c4-4581-b768-082826b96f90} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60730) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.706142 [ 22712 ] {67e4ff33-85c4-4581-b768-082826b96f90} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.730863 [ 22700 ] {c363ef1e-ca9d-4fcf-afdb-cabee91df3ad} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60778) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.753352 [ 22700 ] {c363ef1e-ca9d-4fcf-afdb-cabee91df3ad} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.805224 [ 6986 ] {463d864c-f7ae-4792-8167-9a561a0d659f} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60794) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.819920 [ 6986 ] {463d864c-f7ae-4792-8167-9a561a0d659f} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.866455 [ 22712 ] {c6048d1c-1931-411c-bad1-532dd9cf19fb} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60796) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.884992 [ 22712 ] {c6048d1c-1931-411c-bad1-532dd9cf19fb} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:42.924979 [ 22679 ] {ce949619-c667-4572-841c-8bc39f87c9cb} executeQuery: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60826) (comment: 00427_alter_primary_key.sh) (in query: ALTER TABLE alter_00427 MODIFY COLUMN a Enum8('foo'=1, 'bar'=2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:42.927348 [ 22679 ] {ce949619-c667-4572-841c-8bc39f87c9cb} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:42.937579 [ 6986 ] {cb586012-be5f-424c-86bb-ccbc8db6bcb3} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60812) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.128192 [ 22679 ] {1b410d75-8e9c-407f-9433-f8952f752b0d} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60854) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.128459 [ 22712 ] {7c0fe7e2-e7b5-487d-abe5-41331745584e} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60848) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.130576 [ 11749 ] {c6348923-1264-4415-855c-fb2f2526de7e} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60842) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.165374 [ 6986 ] {cb586012-be5f-424c-86bb-ccbc8db6bcb3} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.165677 [ 22679 ] {1b410d75-8e9c-407f-9433-f8952f752b0d} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.193360 [ 22712 ] {7c0fe7e2-e7b5-487d-abe5-41331745584e} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.213671 [ 11749 ] {c6348923-1264-4415-855c-fb2f2526de7e} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.279304 [ 22706 ] {f84a3313-21ca-4592-b940-091b00368130} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60858) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.283279 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:43.298011 [ 22706 ] {f84a3313-21ca-4592-b940-091b00368130} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.321539 [ 3240 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:43.359913 [ 23388 ] {39e339d8-9897-4f1f-aab9-0ebd682eb01f} executeQuery: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60872) (comment: 00427_alter_primary_key.sh) (in query: ALTER TABLE alter_00427 MODIFY COLUMN b UInt32), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:43.363591 [ 23388 ] {39e339d8-9897-4f1f-aab9-0ebd682eb01f} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:43.607351 [ 11749 ] {4057b558-39e0-4f75-9a0f-711087bd2fb2} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60906) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.622627 [ 11749 ] {4057b558-39e0-4f75-9a0f-711087bd2fb2} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.683557 [ 4371 ] {6ac11fa6-8a9c-400b-a2a6-fced4909ff97} executeQuery: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60952) (comment: 00427_alter_primary_key.sh) (in query: ALTER TABLE alter_00427 MODIFY COLUMN c UInt32), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:43.686576 [ 4371 ] {6ac11fa6-8a9c-400b-a2a6-fced4909ff97} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153fd4d 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:17:43.730246 [ 22679 ] {bbb9d8d8-1dab-4700-9737-c9e2bce7d032} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60928) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:43.745116 [ 22679 ] {bbb9d8d8-1dab-4700-9737-c9e2bce7d032} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.016707 [ 22679 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:44.041758 [ 22700 ] {78eba355-c5c4-47a0-b9ac-84f300543cec} executeQuery: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60998) (comment: 00427_alter_primary_key.sh) (in query: INSERT INTO alter_00427 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:44.048592 [ 11749 ] {8845820d-53a7-4d6c-bd73-367d643c6016} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60982) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.050620 [ 22700 ] {78eba355-c5c4-47a0-b9ac-84f300543cec} TCPHandler: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c327 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000115f4b0f 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb715 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:44.051627 [ 11749 ] {8845820d-53a7-4d6c-bd73-367d643c6016} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.322720 [ 3233 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:44.340007 [ 23439 ] {71f55729-d580-425c-9483-27d502ae4c12} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32796) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.377148 [ 23439 ] {71f55729-d580-425c-9483-27d502ae4c12} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.443303 [ 22679 ] {d7d61e84-e8be-4a53-9be9-4897b4a0c684} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT d FROM alter_00427 WHERE a = 'bar'. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40308) (comment: 00427_alter_primary_key.sh) (in query: SELECT d FROM alter_00427 WHERE a = 'bar'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:44.448091 [ 22679 ] {d7d61e84-e8be-4a53-9be9-4897b4a0c684} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT d FROM alter_00427 WHERE a = 'bar'. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:44.487585 [ 22700 ] {0f23852c-fc23-4af5-b943-dbefa59b7914} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40306) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.520588 [ 22700 ] {0f23852c-fc23-4af5-b943-dbefa59b7914} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.804610 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:44.814732 [ 22679 ] {9a7fc82e-59ad-4026-b876-edb92831622b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT a, b, b = toUnixTimestamp(c) FROM alter_00427 ORDER BY a ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40332) (comment: 00427_alter_primary_key.sh) (in query: SELECT a, b, b = toUnixTimestamp(c) FROM alter_00427 ORDER BY a FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:44.817333 [ 22700 ] {fc284403-5a36-4d1b-b015-d8ea87982188} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40322) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:44.819229 [ 22679 ] {9a7fc82e-59ad-4026-b876-edb92831622b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT a, b, b = toUnixTimestamp(c) FROM alter_00427 ORDER BY a ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:44.825409 [ 22700 ] {fc284403-5a36-4d1b-b015-d8ea87982188} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.013032 [ 23439 ] {cc3d94be-c5d8-400f-a433-4cf8773fbaae} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40342) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.017272 [ 23439 ] {cc3d94be-c5d8-400f-a433-4cf8773fbaae} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.323712 [ 3185 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:45.475438 [ 22700 ] {97f54592-f20e-462d-95ea-6e706c5d7fec} executeQuery: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40348) (comment: 00427_alter_primary_key.sh) (in query: DROP TABLE alter_00427), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:17:45.478480 [ 22700 ] {97f54592-f20e-462d-95ea-6e706c5d7fec} TCPHandler: Code: 60. DB::Exception: Table test_b3za3bmn.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000010e182c9 5. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000111763cc 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c4bc 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572074 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 10. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:17:45.577971 [ 23493 ] {f900ec10-7368-405c-a0b5-fc0dbb863f39} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40374) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.595804 [ 4371 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:45.609920 [ 23493 ] {f900ec10-7368-405c-a0b5-fc0dbb863f39} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.723147 [ 22679 ] {6119be7b-2225-4529-952b-7351adef1c04} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40362) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:45.725425 [ 22679 ] {6119be7b-2225-4529-952b-7351adef1c04} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:46.108593 [ 22700 ] {93e3c961-cc49-420f-81d4-f6b704f5d020} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40384) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:46.134094 [ 22700 ] {93e3c961-cc49-420f-81d4-f6b704f5d020} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:46.328124 [ 22679 ] {6e02d7d4-d468-4a4c-8b4d-24232e97ab0c} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40398) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:46.331034 [ 22705 ] {d0f96680-a6e5-44eb-8cf7-dd5c8d59e768} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60832). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60832) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf834 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:46.331070 [ 3139 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:46.333035 [ 22679 ] {6e02d7d4-d468-4a4c-8b4d-24232e97ab0c} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 7 and result: 8). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000007c6d06b 4. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000010fd31cc 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000115f894f 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:46.334807 [ 22679 ] {6e02d7d4-d468-4a4c-8b4d-24232e97ab0c} TCPHandler: Client has gone away. 2025.06.25 16:17:46.338153 [ 22705 ] {d0f96680-a6e5-44eb-8cf7-dd5c8d59e768} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60832). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:46.339177 [ 22705 ] {d0f96680-a6e5-44eb-8cf7-dd5c8d59e768} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60832). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf834 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:46.342077 [ 22705 ] {d0f96680-a6e5-44eb-8cf7-dd5c8d59e768} TCPHandler: Client has gone away. 2025.06.25 16:17:46.373056 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:46.705461 [ 22706 ] {9b317241-e409-4e44-983c-09bf4872fed5} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60938). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60938) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:46.725831 [ 22706 ] {9b317241-e409-4e44-983c-09bf4872fed5} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60938). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:46.729402 [ 22706 ] {9b317241-e409-4e44-983c-09bf4872fed5} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60938). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:46.732227 [ 22706 ] {9b317241-e409-4e44-983c-09bf4872fed5} TCPHandler: Client has gone away. 2025.06.25 16:17:46.995345 [ 23388 ] {030f28a3-caca-4509-9540-62f735e20e99} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60956). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60956) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:47.007120 [ 23388 ] {030f28a3-caca-4509-9540-62f735e20e99} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60956). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:47.008136 [ 23388 ] {030f28a3-caca-4509-9540-62f735e20e99} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60956). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:47.018557 [ 23388 ] {030f28a3-caca-4509-9540-62f735e20e99} TCPHandler: Client has gone away. 2025.06.25 16:17:47.111745 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:47.139532 [ 6398 ] {698320eb-a910-4d8e-a5a3-fba58e342792} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60944). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60944) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT * FROM system.parts FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:47.159439 [ 6398 ] {698320eb-a910-4d8e-a5a3-fba58e342792} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60944). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:47.161183 [ 6398 ] {698320eb-a910-4d8e-a5a3-fba58e342792} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:60944). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x0000000012cc3a61 5. /build/src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf651 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:17:47.163484 [ 6398 ] {698320eb-a910-4d8e-a5a3-fba58e342792} TCPHandler: Client has gone away. 2025.06.25 16:17:47.297170 [ 22705 ] {c3254da7-7d52-478b-924c-04e719f09756} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40470) (comment: 01632_tinylog_read_write.sh) (in query: SELECT * FROM test FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:47.312542 [ 22705 ] {c3254da7-7d52-478b-924c-04e719f09756} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=759, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:47.336821 [ 3303 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:47.886228 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:48.337805 [ 3103 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:48.482518 [ 4197 ] {54a06a67-a3fe-44b2-9e40-7abef3f6afc8} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59520). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59520) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x0000000012cc4911 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5e5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:48.485544 [ 4197 ] {54a06a67-a3fe-44b2-9e40-7abef3f6afc8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59520). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:48.487265 [ 4197 ] {54a06a67-a3fe-44b2-9e40-7abef3f6afc8} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59520). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x0000000012cc4911 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5e5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:48.504948 [ 4197 ] {54a06a67-a3fe-44b2-9e40-7abef3f6afc8} TCPHandler: Client has gone away. 2025.06.25 16:17:48.603221 [ 2956 ] {b53c76cd-4d06-4d30-abfd-e296bcb6b512} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59566). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59566) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: INSERT INTO alter_table0 SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x0000000012cc4911 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5e5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:48.606662 [ 2956 ] {b53c76cd-4d06-4d30-abfd-e296bcb6b512} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59566). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:48.616788 [ 2956 ] {b53c76cd-4d06-4d30-abfd-e296bcb6b512} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:59566). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x0000000012cc4911 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5e5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:17:48.619180 [ 2956 ] {b53c76cd-4d06-4d30-abfd-e296bcb6b512} TCPHandler: Client has gone away. 2025.06.25 16:17:48.663192 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:48.795178 [ 3626 ] {} a98ec78a-d8bb-4384-8292-84da692a5198::-1_7_7_0_17 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:48.795948 [ 3626 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a98ec78a-d8bb-4384-8292-84da692a5198::-1_7_7_0_17}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:48.933520 [ 4370 ] {b567ef09-2b7e-4d3b-984e-ce4b3132b6c7} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60946) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.935308 [ 4370 ] {b567ef09-2b7e-4d3b-984e-ce4b3132b6c7} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.936476 [ 4370 ] {b567ef09-2b7e-4d3b-984e-ce4b3132b6c7} TCPHandler: Client has gone away. 2025.06.25 16:17:48.937085 [ 22712 ] {262d0bca-2a55-4c7b-9e82-a8217e67f156} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60920) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.938748 [ 22712 ] {262d0bca-2a55-4c7b-9e82-a8217e67f156} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.938837 [ 6986 ] {7c998226-0398-4f16-938a-38e1097e7b59} executeQuery: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60892) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 ADD COLUMN h String DEFAULT '0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.940709 [ 6986 ] {7c998226-0398-4f16-938a-38e1097e7b59} TCPHandler: Code: 15. DB::Exception: Cannot add column `h`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfba3 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:17:48.940892 [ 22712 ] {262d0bca-2a55-4c7b-9e82-a8217e67f156} TCPHandler: Client has gone away. 2025.06.25 16:17:48.941695 [ 6986 ] {7c998226-0398-4f16-938a-38e1097e7b59} TCPHandler: Client has gone away. 2025.06.25 16:17:49.053134 [ 3624 ] {} 26ac94f5-e11e-45e1-9d6f-ddfbb4d140e4::-1_7_7_0_17 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:49.053962 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {26ac94f5-e11e-45e1-9d6f-ddfbb4d140e4::-1_7_7_0_17}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:49.349138 [ 3121 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:49.435133 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:49.661523 [ 3628 ] {} a98ec78a-d8bb-4384-8292-84da692a5198::-1_0_0_0_23 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000128fef7a 17. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 19. /build/src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8bd1 20. /build/src/QueryPipeline/QueryPipelineBuilder.h:160: DB::MutationsInterpreter::execute() @ 0x00000000116eb331 21. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000012964c3a 22. /build/src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x00000000129634b1 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c8cd9 24. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7ab6 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 27. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 29. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 31. ? @ 0x00007f597a7a2ac3 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:49.666736 [ 3628 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a98ec78a-d8bb-4384-8292-84da692a5198::-1_0_0_0_23}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000128fef7a 17. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 19. /build/src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8bd1 20. /build/src/QueryPipeline/QueryPipelineBuilder.h:160: DB::MutationsInterpreter::execute() @ 0x00000000116eb331 21. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000012964c3a 22. /build/src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x00000000129634b1 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x00000000129c8cd9 24. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x00000000129c7ab6 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 27. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 29. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 31. ? @ 0x00007f597a7a2ac3 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:49.890234 [ 6398 ] {d5cab31e-3703-46fe-a25f-3a520dcf4ecd} executeQuery: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40894) (comment: 02788_current_schemas_function.sql) (in query: SELECT current_schemas(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/currentSchemas.cpp:0: DB::(anonymous namespace)::FunctionCurrentSchemas::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084591e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:17:49.892955 [ 6398 ] {d5cab31e-3703-46fe-a25f-3a520dcf4ecd} TCPHandler: Code: 43. DB::Exception: Argument for function currentSchemas must be bool: In scope SELECT current_schemas(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/currentSchemas.cpp:0: DB::(anonymous namespace)::FunctionCurrentSchemas::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084591e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:17:49.903465 [ 22694 ] {25d14cca-37dc-4eca-9b89-40ee90e347ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40932) (comment: 01632_tinylog_read_write.sh) (in query: SELECT * FROM test FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:49.909943 [ 22694 ] {25d14cca-37dc-4eca-9b89-40ee90e347ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:49.959510 [ 6398 ] {bb819a71-0a46-44c4-b0b6-7d3d5243efd6} 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.10505.altinitytest (altinity build)) (from [::1]:40894) (comment: 02788_current_schemas_function.sql) (in query: SELECT current_schemas();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:17:49.962632 [ 6398 ] {bb819a71-0a46-44c4-b0b6-7d3d5243efd6} 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), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:17:50.039306 [ 3622 ] {} test_s492y1th.alter_table0 (ReplicatedMergeTreeQueue): There are no mutations for partition ID -4 (trying to mutate part -4_0_0_0 to 41) 2025.06.25 16:17:50.143753 [ 6155 ] {c88ca838-c8af-41f0-949e-6b32277cc60c} executeQuery: Code: 341. DB::Exception: Mutation 0000000026 was killed, manually removed or table was dropped. (UNFINISHED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59536) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: ALTER TABLE alter_table0 DROP COLUMN h;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000001235cdf9 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000123e07fa 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123de525 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:50.173722 [ 6155 ] {c88ca838-c8af-41f0-949e-6b32277cc60c} TCPHandler: Code: 341. DB::Exception: Mutation 0000000026 was killed, manually removed or table was dropped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:612: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x000000001235cdf9 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x00000000123e07fa 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000123de525 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f019 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:50.175088 [ 6155 ] {c88ca838-c8af-41f0-949e-6b32277cc60c} TCPHandler: Client has gone away. 2025.06.25 16:17:50.363893 [ 3155 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:50.388017 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:50.506863 [ 22694 ] {a246f300-fa3c-476b-8e76-3d5aaa7217da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40982) (comment: 00990_hasToken_and_tokenbf.sql) (in query: CREATE TABLE bloom_filter (`id` UInt64, `s` String, INDEX tok_bf (s, lower(s)) TYPE tokenbf_v1(512, 3, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9967761635780334, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 263636674, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 9795386, merge_max_block_size = 13178, old_parts_lifetime = 351., 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 = 1607050876, concurrent_part_removal_threshold = 63, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 37629, primary_key_compress_block_size = 82396), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:50.510996 [ 22694 ] {a246f300-fa3c-476b-8e76-3d5aaa7217da} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001278a572 9. /build/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>) @ 0x0000000012a75d2c 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: 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>&&) @ 0x0000000012a757f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a7170f 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:17:51.135751 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:51.365942 [ 3238 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:51.903012 [ 4197 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:52.165082 [ 3059 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:52.368586 [ 3347 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:52.605204 [ 6665 ] {7c7e1f61-7166-412e-973f-e0d072ae8b1f} StatusRequestsPool: Error scheduling get status task for table test_s492y1th.alter_table0 (a98ec78a-d8bb-4384-8292-84da692a5198): 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010440e4d 8. /build/contrib/llvm-project/libcxx/include/new:246: DB::ReadFromSystemReplicas::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001043d377 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:52.622421 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:52.690583 [ 6665 ] {7c7e1f61-7166-412e-973f-e0d072ae8b1f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing SystemReplicas. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41294) (comment: 00992_system_parts_race_condition_zookeeper_long.sh) (in query: SELECT count() - sum(is_readonly) FROM system.replicas WHERE database=currentDatabase() AND table LIKE 'alter_table%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010440e4d 8. /build/contrib/llvm-project/libcxx/include/new:246: DB::ReadFromSystemReplicas::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001043d377 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:52.699529 [ 6665 ] {7c7e1f61-7166-412e-973f-e0d072ae8b1f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing SystemReplicas. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010440e4d 8. /build/contrib/llvm-project/libcxx/include/new:246: DB::ReadFromSystemReplicas::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001043d377 9. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:17:53.371126 [ 3422 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:53.386249 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:54.131206 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:54.374040 [ 3173 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:54.900759 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:55.377962 [ 3197 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:55.807236 [ 6836 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:56.018968 [ 22705 ] {18f13e25-24a5-4e5c-b27e-3c4ceaa80fd5} executeQuery: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46352) (comment: 01352_generate_random_overflow.sql) (in query: SELECT i FROM generateRandom('i Array(Nullable(Enum8(\'hello\' = 1, \'world\' = 5)))', 1025, 65535, 9223372036854775807) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/Storages/StorageGenerateRandom.cpp:0: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x00000000122804e1 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x0000000010289e47 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000010289a29 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 8. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:17:56.021530 [ 22705 ] {18f13e25-24a5-4e5c-b27e-3c4ceaa80fd5} TCPHandler: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/Storages/StorageGenerateRandom.cpp:0: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x00000000122804e1 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x0000000010289e47 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000010289a29 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 8. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:17:56.380042 [ 3348 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:56.682755 [ 4370 ] {e81e5f4a-fcfd-4a2d-8ef3-6adc3bfb0872} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46242) (comment: 01681_cache_dictionary_simple_key.sql) (in query: SELECT 'dictGetOrDefault existing value';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:56.688219 [ 4370 ] {e81e5f4a-fcfd-4a2d-8ef3-6adc3bfb0872} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:17:56.738552 [ 22711 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:57.382618 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:57.682412 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:57.816158 [ 6986 ] {ae05dd35-86a7-4cb7-9a0e-9e8960d4a7e3} executeQuery: Code: 497. DB::Exception: u_02311: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(path, name, value) ON system.zookeeper. (ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46442) (in query: insert into system.zookeeper (path, name, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Access/ContextAccess.cpp: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 @ 0x00000000107e2784 5. /build/src/Access/ContextAccess.cpp:647: 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'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107e23da 6. /build/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 @ 0x00000000107e1ac5 7. /build/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 @ 0x00000000107c5f06 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000001110513a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1e89 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x00000000115fba09 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:17:57.818951 [ 6986 ] {ae05dd35-86a7-4cb7-9a0e-9e8960d4a7e3} TCPHandler: Code: 497. DB::Exception: u_02311: Not enough privileges. To execute this query, it's necessary to have the grant INSERT(path, name, value) ON system.zookeeper. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Access/ContextAccess.cpp: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 @ 0x00000000107e2784 5. /build/src/Access/ContextAccess.cpp:647: 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'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x00000000107e23da 6. /build/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 @ 0x00000000107e1ac5 7. /build/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 @ 0x00000000107c5f06 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x000000001110513a 9. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000110e1e89 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x00000000115fba09 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:17:58.168015 [ 11749 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:58.386520 [ 3498 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:58.442472 [ 6986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:59.016858 [ 5782 ] {2db4ad68-ef9a-40d7-9a5f-0997ca8fe9ce} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_xwiki562.async_inserts FORMAT CSV' with query id d232af30-c227-4ddf-8472-7ee09d8ba586. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) 2025.06.25 16:17:59.065129 [ 6155 ] {d232af30-c227-4ddf-8472-7ee09d8ba586} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42988) (comment: 02015_async_inserts_2.sh) (in query: INSERT INTO async_inserts FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000012e0cca7 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de619d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute() @ 0x0000000012d72a7a 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000012d7293c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000110b0e0d 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000110b3da4 15. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 16. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 17. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:17:59.085415 [ 6155 ] {d232af30-c227-4ddf-8472-7ee09d8ba586} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: 'qqqqqqqqqqq': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing WaitForAsyncInsert. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000c6b0ec1 5. /build/src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000012e0cca7 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000012de619d 7. /build/src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x0000000012dc8089 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x0000000012d73996 9. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 10. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute() @ 0x0000000012d72a7a 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:0: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x0000000012d7293c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000110b0e0d 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000110b3da4 15. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 16. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 17. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:59.243581 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:17:59.393113 [ 3290 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:17:59.508347 [ 6836 ] {400468b0-ba95-4b52-9b00-a533cdaf0f11} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46366) (comment: 02898_default_190aed82-2423-413b-ad4c-24dcca50f65b) (in query: -- default coordinator SELECT count(), min(k), max(k), avg(k) FROM t1 SETTINGS log_comment='02898_default_190aed82-2423-413b-ad4c-24dcca50f65b';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:17:59.514115 [ 6836 ] {400468b0-ba95-4b52-9b00-a533cdaf0f11} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:18:00.023978 [ 11749 ] {9d016dc7-e75a-44c2-8044-9622044140fb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49290) (comment: 02015_async_inserts_2.sh) (in query: DROP DATABASE IF EXISTS test_xwiki562 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:18:00.030118 [ 11749 ] {9d016dc7-e75a-44c2-8044-9622044140fb} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:00.279088 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:00.398227 [ 3397 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:00.776049 [ 22694 ] {80e91a4e-2ecb-4eef-bda9-2255c44d5aec} executeQuery: Code: 57. DB::Exception: Table test_13.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46544) (comment: 02789_set_index_nullable_condition_bug.sql) (in query: CREATE TABLE test_table (`col1` String, `col2` String, INDEX test_table_col2_idx col2 TYPE set(0) GRANULARITY 1) ENGINE = MergeTree ORDER BY col1 SETTINGS index_granularity = 12020, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 98, min_bytes_for_full_part_storage = 358887695, compact_parts_max_bytes_to_buffer = 132346143, compact_parts_max_granules_to_buffer = 167, compact_parts_merge_max_bytes_to_prefetch_part = 5418615, merge_max_block_size = 7427, old_parts_lifetime = 190., prefer_fetch_merged_part_size_threshold = 1490522476, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2878772794, index_granularity_bytes = 998801, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 15302, primary_key_compress_block_size = 9417 AS SELECT 'v1', 'v2'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:00.784452 [ 22694 ] {80e91a4e-2ecb-4eef-bda9-2255c44d5aec} TCPHandler: Code: 57. DB::Exception: Table test_13.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:01.207956 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:01.415523 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:02.198688 [ 6155 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:02.422048 [ 3457 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:03.058560 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:03.096573 [ 6155 ] {25e97834-a945-4f20-af2f-4a61fda138ce} 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.10505.altinitytest (altinity build)) (from [::1]:46598) (comment: 01408_range_overflow.sql) (in query: SELECT range(1025, 18446744073709551615, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/array/range.cpp:0: COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000000c5fab35 5. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c5e817e 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:18:03.099302 [ 6155 ] {25e97834-a945-4f20-af2f-4a61fda138ce} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/array/range.cpp:0: COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000000c5fab35 5. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c5e817e 6. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 7. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 17. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 20. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 23. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 24. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:18:03.424206 [ 3412 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:03.871457 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:04.428911 [ 3424 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:04.937185 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:05.434631 [ 3428 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:05.715975 [ 22699 ] {7555b460-3277-4f0f-b3f8-9154d2bf71af} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01710_minmax_count_projection.sql) (in query: /* ddl_entry=query-0000000146 */ CREATE TABLE test_11.t UUID '9a980e51-bedc-444f-a310-eb1eb877d0fc' (`server_date` Date, `something` String) ENGINE = MergeTree PARTITION BY (toYYYYMM(server_date), server_date) ORDER BY (server_date, something) SETTINGS index_granularity = 37629, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9630842804908752, 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 = 100892839, compact_parts_max_granules_to_buffer = 82, compact_parts_merge_max_bytes_to_prefetch_part = 32598599, merge_max_block_size = 8513, old_parts_lifetime = 385., prefer_fetch_merged_part_size_threshold = 2369943732, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4791593472, index_granularity_bytes = 10501245, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 24334, primary_key_compress_block_size = 38992), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:18:05.761287 [ 22699 ] {7555b460-3277-4f0f-b3f8-9154d2bf71af} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60034) (comment: 01710_minmax_count_projection.sql) (in query: CREATE TABLE t (`server_date` Date, `something` String) ENGINE = MergeTree PARTITION BY (toYYYYMM(server_date), server_date) ORDER BY (server_date, something) SETTINGS index_granularity = 37629, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9630842804908752, 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 = 100892839, compact_parts_max_granules_to_buffer = 82, compact_parts_merge_max_bytes_to_prefetch_part = 32598599, merge_max_block_size = 8513, old_parts_lifetime = 385., prefer_fetch_merged_part_size_threshold = 2369943732, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4791593472, index_granularity_bytes = 10501245, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 24334, primary_key_compress_block_size = 38992), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:18:05.767818 [ 22699 ] {7555b460-3277-4f0f-b3f8-9154d2bf71af} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:18:05.862556 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:06.436466 [ 3100 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:06.780740 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:07.379511 [ 23388 ] {048f6c91-a9ff-43ca-bf01-cdbefaa2ef20} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50954) (comment: 00977_int_div.sql) (in query: SELECT -1 DIV 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x0000000008bca974 5. /build/src/Functions/DivisionUtils.h:59: 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 @ 0x000000000974f2fe 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x000000000974e210 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x0000000009710283 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:18:07.381907 [ 23388 ] {048f6c91-a9ff-43ca-bf01-cdbefaa2ef20} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x0000000008bca974 5. /build/src/Functions/DivisionUtils.h:59: 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 @ 0x000000000974f2fe 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x000000000974e210 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x0000000009710283 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:18:07.440984 [ 3179 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:07.578202 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:08.111940 [ 3691 ] {4e039aee-092d-44a2-9b82-23299e6c65d9} ExternalDictionariesLoader: Could not load external dictionary '5b700fe5-4263-4fee-8a5a-f5dcf7a75f91', next update is scheduled at 2025-06-25 16:18:14: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2): (while reading column EndDate): (while reading from part /var/lib/clickhouse/store/9f6/9f6e7cd0-ec10-4114-9065-6b813832b5ea/all_2_2_0/ in table test_11.date_table (9f6e7cd0-ec10-4114-9065-6b813832b5ea) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 14. /build/src/Common/PODArray.h:315: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42d6 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5efb 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2e69c 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:08.118634 [ 22700 ] {4e039aee-092d-44a2-9b82-23299e6c65d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2): (while reading column EndDate): (while reading from part /var/lib/clickhouse/store/9f6/9f6e7cd0-ec10-4114-9065-6b813832b5ea/all_2_2_0/ in table test_11.date_table (9f6e7cd0-ec10-4114-9065-6b813832b5ea) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread): In scope SELECT dictGet('range_dictionary', 'Tax', toUInt64(1), toDate('2019-05-15')). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50972) (comment: 01676_range_hashed_dictionary.sql) (in query: SELECT dictGet('range_dictionary', 'Tax', toUInt64(1), toDate('2019-05-15'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 14. /build/src/Common/PODArray.h:315: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42d6 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5efb 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2e69c 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 2025.06.25 16:18:08.122375 [ 22700 ] {4e039aee-092d-44a2-9b82-23299e6c65d9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2): (while reading column EndDate): (while reading from part /var/lib/clickhouse/store/9f6/9f6e7cd0-ec10-4114-9065-6b813832b5ea/all_2_2_0/ in table test_11.date_table (9f6e7cd0-ec10-4114-9065-6b813832b5ea) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread): In scope SELECT dictGet('range_dictionary', 'Tax', toUInt64(1), toDate('2019-05-15')). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/ReadBuffer.h:183: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x00000000073d7657 14. /build/src/Common/PODArray.h:315: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42d6 15. /build/src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5efb 16. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d2e69c 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 19. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 2025.06.25 16:18:08.446690 [ 3416 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:08.459089 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:09.350941 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:09.451534 [ 3350 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:10.350707 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:10.465845 [ 3257 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:11.192022 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:11.496679 [ 22694 ] {0df5f42d-2ce2-41f5-a6e0-d56a70d35505} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46560) (comment: 02706_show_columns.sql) (in query: DROP DATABASE database_123456789abcde;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:11.502960 [ 22694 ] {0df5f42d-2ce2-41f5-a6e0-d56a70d35505} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:11.529514 [ 3008 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:12.080969 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:12.531367 [ 3328 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:12.885870 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:13.538605 [ 3146 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:13.668861 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:14.176577 [ 23388 ] {11f3e825-d73a-4624-b946-6a518aa1b5d2} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(1, 3600 - timeZoneOffset(CAST('2024-05-06 12:00:00', 'DateTime'))) SETTINGS session_timezone = 'Europe/Lisbon'. (ILLEGAL_DIVISION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52168) (comment: 00265_http_content_type_format_timezone.sh) (in query: SELECT intDiv(1, (3600-timeZoneOffset('2024-05-06 12:00:00'::DateTime))) SETTINGS session_timezone = 'Europe/Lisbon' ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x0000000008bcae74 5. /build/src/Functions/DivisionUtils.h:59: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009715619 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x0000000009711011 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x000000000970ff87 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 2025.06.25 16:18:14.180217 [ 23388 ] {11f3e825-d73a-4624-b946-6a518aa1b5d2} DynamicQueryHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(1, 3600 - timeZoneOffset(CAST('2024-05-06 12:00:00', 'DateTime'))) SETTINGS session_timezone = 'Europe/Lisbon'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Functions/DivisionUtils.h:0: void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x0000000008bcae74 5. /build/src/Functions/DivisionUtils.h:59: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000009715619 6. /build/src/Functions/FunctionBinaryArithmetic.h:2321: 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&&) @ 0x0000000009711011 7. /build/src/Functions/FunctionBinaryArithmetic.h:821: 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&&) @ 0x000000000970ff87 8. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000970c200 9. /build/src/Functions/FunctionBinaryArithmetic.h:2224: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970a7b7 10. /build/src/Functions/FunctionBinaryArithmetic.h:2461: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000970986a 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 20. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:14.490566 [ 22667 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:14.544520 [ 3358 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:15.478745 [ 22667 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:15.554203 [ 3313 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:16.303038 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:16.561190 [ 3491 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:16.720505 [ 23493 ] {c1dc6eb7-0aa9-45b2-8b80-43fd80c09fe1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53760) (comment: 01355_ilike.sql) (in query: SELECT 'hEllo' ILIKE '%HEL%';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:16.724766 [ 23493 ] {c1dc6eb7-0aa9-45b2-8b80-43fd80c09fe1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=742). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:17.207491 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:17.644328 [ 3437 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:18.085251 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:18.648781 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:19.066581 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:19.653530 [ 3157 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:20.061974 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:20.657249 [ 3311 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:20.798616 [ 11749 ] {5b58c4e7-a183-4f36-9654-1caaf103bdcc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51056) (comment: 02706_show_columns.sql) (in query: DROP DATABASE database_123456789abcde;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:20.805738 [ 11749 ] {5b58c4e7-a183-4f36-9654-1caaf103bdcc} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:21.032359 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:21.658995 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:21.838871 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:22.664703 [ 3044 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:22.788153 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:23.171632 [ 23493 ] {a3c405ba-3970-45dc-8ce7-cf2433d26fd2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53906) (comment: 02014_query_parameters.sh) (in query: DROP DATABASE test_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:23.183766 [ 23493 ] {a3c405ba-3970-45dc-8ce7-cf2433d26fd2} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:23.670172 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:23.707856 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:24.453489 [ 23493 ] {a3f73c08-5fc0-4940-abec-53d150a4a925} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57370) (comment: 02014_query_parameters.sh) (in query: DROP DATABASE IF EXISTS test_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:24.461373 [ 23493 ] {a3f73c08-5fc0-4940-abec-53d150a4a925} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:24.638859 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:24.674665 [ 3193 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:24.922600 [ 23493 ] {fedbe635-62ae-4758-bb9b-7c46b7004351} executeQuery: Code: 82. DB::Exception: Database test_db already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57386) (comment: 02014_query_parameters.sh) (in query: CREATE DATABASE test_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:18:24.930882 [ 23493 ] {fedbe635-62ae-4758-bb9b-7c46b7004351} TCPHandler: Code: 82. DB::Exception: Database test_db already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:18:25.405380 [ 23493 ] {ea6b49cb-1af9-45d3-a833-fb1ca58ea514} executeQuery: Code: 57. DB::Exception: Table test_db.test_t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57398) (comment: 02014_query_parameters.sh) (in query: CREATE TABLE test_db.test_t (`id` UInt64, `col1` UInt64) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 9481, min_bytes_for_wide_part = 418004617, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 50590220, compact_parts_max_granules_to_buffer = 80, compact_parts_merge_max_bytes_to_prefetch_part = 3893138, merge_max_block_size = 2656, old_parts_lifetime = 159., 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 = 5499649673, index_granularity_bytes = 16628560, concurrent_part_removal_threshold = 54, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 77256, primary_key_compress_block_size = 9639), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:25.433269 [ 23493 ] {ea6b49cb-1af9-45d3-a833-fb1ca58ea514} TCPHandler: Code: 57. DB::Exception: Table test_db.test_t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:25.584809 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:25.680140 [ 3288 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:26.264621 [ 22672 ] {a9096e98-6d40-465d-9151-161bd9b5907b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53866) (comment: 02706_show_columns.sql) (in query: SHOW COLUMNS FROM tab LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:26.279901 [ 22672 ] {a9096e98-6d40-465d-9151-161bd9b5907b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:26.510277 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:26.681988 [ 3199 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:27.359366 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:27.684736 [ 3438 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:27.877117 [ 22701 ] {f808c040-113d-4543-a70a-4d39cbcd7568} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `col1` to rename. Maybe you meant: ['col2']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57488) (comment: 02014_query_parameters.sh) (in query: ALTER TABLE test_db.test_t RENAME COLUMN col1 TO col2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfc80 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:18:27.897280 [ 22701 ] {f808c040-113d-4543-a70a-4d39cbcd7568} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `col1` to rename. Maybe you meant: ['col2']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cfc80 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:18:28.212187 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:28.696247 [ 3020 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:28.960672 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:29.697746 [ 3390 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:29.768721 [ 22701 ] {372078a4-7fb2-4e20-9c7b-c0675fcee1fa} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57566) (comment: 02014_query_parameters.sh) (in query: DROP DATABASE test_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:29.783558 [ 22701 ] {372078a4-7fb2-4e20-9c7b-c0675fcee1fa} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:29.805340 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:30.609484 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:30.698963 [ 3295 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:31.568530 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:31.703476 [ 3142 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:32.462371 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:32.789656 [ 3226 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:33.376334 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:33.794400 [ 3414 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:34.210497 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:34.798340 [ 3492 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:35.185059 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:35.817069 [ 3309 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:36.023016 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:36.188974 [ 22701 ] {ad003dbf-1241-4b60-beff-f7cc92ea1e12} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57366) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001225861f 5. /build/src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000122589f7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000012259938 7. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001225aca1 8. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001225b27a 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000001027eb8a 10. /build/src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000001027cfa6 11. /build/src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001027fbe8 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 13. /build/src/Databases/DatabaseFilesystem.cpp:157: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1c4e 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 15. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:18:36.214736 [ 22701 ] {ad003dbf-1241-4b60-beff-f7cc92ea1e12} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000001225861f 5. /build/src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000122589f7 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000012259938 7. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x000000001225aca1 8. /build/src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000001225b27a 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x000000001027eb8a 10. /build/src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x000000001027cfa6 11. /build/src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001027fbe8 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 13. /build/src/Databases/DatabaseFilesystem.cpp:157: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1c4e 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 15. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:18:36.821573 [ 3046 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:36.896800 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:37.130817 [ 5056 ] {8edc42b0-730c-49ff-89bd-35f9a17fb0d9} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57396) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:37.159176 [ 5056 ] {8edc42b0-730c-49ff-89bd-35f9a17fb0d9} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:37.757713 [ 5056 ] {867c4625-eac7-4619-9fb7-e20bd21a4468} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57404) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`/tmp/tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:37.771781 [ 5056 ] {867c4625-eac7-4619-9fb7-e20bd21a4468} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:37.823484 [ 3217 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:37.847410 [ 22701 ] {bd1ceb8f-9c6d-43c4-bb53-d4ad780a9932} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57384) (comment: 01436_storage_merge_with_join_push_down.sql) (in query: DROP TABLE test_merge;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:37.851492 [ 22701 ] {bd1ceb8f-9c6d-43c4-bb53-d4ad780a9932} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:37.877684 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:38.117671 [ 22701 ] {417f5fa4-87eb-4e3c-818d-86ac764e2dfd} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57434) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`../*/tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:38.129354 [ 22701 ] {417f5fa4-87eb-4e3c-818d-86ac764e2dfd} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:38.566374 [ 22701 ] {15a0a582-757d-42cd-babd-4613e587d529} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57452) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`../tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:38.582203 [ 22701 ] {15a0a582-757d-42cd-babd-4613e587d529} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:38.791137 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:38.828021 [ 3306 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:39.060098 [ 22701 ] {034c2881-71a3-40d0-aad0-1f1e4a292763} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57478) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`../*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:39.069557 [ 22701 ] {034c2881-71a3-40d0-aad0-1f1e4a292763} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:39.218978 [ 5056 ] {d41dacd9-d6a3-484c-adf8-274cd632ab81} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57484) (comment: 02932_non_ready_set_stuck.sql) (in query: CREATE TABLE tab (`item_id` UInt64, `price_sold` Nullable(Float32), `date` Date) ENGINE = MergeTree ORDER BY item_id SETTINGS index_granularity = 35425, min_bytes_for_wide_part = 878173842, ratio_of_defaults_for_sparse_serialization = 0.541850209236145, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 184368246, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 6378208, merge_max_block_size = 5337, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9283180436, index_granularity_bytes = 2433353, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 86080, primary_key_compress_block_size = 64194), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:39.228049 [ 5056 ] {d41dacd9-d6a3-484c-adf8-274cd632ab81} TCPHandler: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:18:39.548184 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:39.631535 [ 22701 ] {d56ce78e-811b-44f7-8035-965e1e474a60} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57486) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM "../02722_database_filesystem_test_fdxrq7bd/tmp.csv";), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:39.641705 [ 22701 ] {d56ce78e-811b-44f7-8035-965e1e474a60} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:39.832349 [ 3085 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:39.993333 [ 22701 ] {a086f3c3-4668-428d-998f-2537e4778c25} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57500) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`../../../../../../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:40.017772 [ 22701 ] {a086f3c3-4668-428d-998f-2537e4778c25} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000010da1484 5. /build/src/Databases/DatabaseFilesystem.cpp:147: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010da1a38 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000010da2184 7. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000011177501 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117c217 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr) @ 0x0000000011089afa 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000110472bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105ed06 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:18:40.554494 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:40.645602 [ 22701 ] {a2f484e8-2a7c-4b61-baac-4db6dac512ca} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57516) (comment: 02722_database_filesystem.sh) (in query: CREATE DATABASE test2 ENGINE = Filesystem('/tmp');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000010da0a29 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000010da55f8 6. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010da2cee 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:18:40.662155 [ 22701 ] {a2f484e8-2a7c-4b61-baac-4db6dac512ca} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Databases/DatabaseFilesystem.cpp:0: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000010da0a29 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000010da55f8 6. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010da2cee 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:18:40.834333 [ 3519 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:41.351609 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:41.372110 [ 22701 ] {9e09ca14-5b15-4b2d-804e-08c4e27147b6} executeQuery: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57538) (comment: 02722_database_filesystem.sh) (in query: CREATE DATABASE test2 ENGINE = Filesystem('relative_unknown_dir');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Databases/DatabaseFilesystem.cpp:55: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000010da0aac 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000010da55f8 6. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010da2cee 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:18:41.389179 [ 22701 ] {9e09ca14-5b15-4b2d-804e-08c4e27147b6} TCPHandler: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Databases/DatabaseFilesystem.cpp:55: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000010da0aac 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String&, std::shared_ptr&, void>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000010da55f8 6. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010da2cee 7. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 8. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:18:41.841499 [ 3517 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:42.008936 [ 5056 ] {adf63dbe-4052-402c-ac2d-fac674591b1f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test1.tmp2.csv' in scope SELECT COUNT(*) FROM test1.`tmp2.csv`. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57582) (comment: 02722_database_filesystem.sh) (in query: SELECT COUNT(*) FROM test1.`tmp2.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:18:42.025611 [ 5056 ] {adf63dbe-4052-402c-ac2d-fac674591b1f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test1.tmp2.csv' in scope SELECT COUNT(*) FROM test1.`tmp2.csv`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:18:42.167713 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:42.844871 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:42.960180 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:43.721618 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:43.852652 [ 3129 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:44.092986 [ 22701 ] {56ca4492-9299-4c4f-aa75-39f50ad08e75} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57618) (comment: 03040_dynamic_type_alters_1_memory.sql) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:18:44.131953 [ 22701 ] {56ca4492-9299-4c4f-aa75-39f50ad08e75} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:18:44.514036 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:44.843126 [ 22672 ] {8f5b4d27-91de-4823-a5c7-e7b228302d9f} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55036) (comment: 01070_h3_to_children.sql) (in query: SELECT h3ToChildren(599405990164561919, 16);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/h3ToChildren.cpp:0: DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000935b02a 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:18:44.845588 [ 22672 ] {8f5b4d27-91de-4823-a5c7-e7b228302d9f} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000070b8cab 4. /build/src/Functions/h3ToChildren.cpp:0: DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000935b02a 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:18:44.853930 [ 3142 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:45.321799 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:45.861581 [ 3031 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:46.091809 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:46.862859 [ 3506 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:46.925287 [ 22711 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:47.734569 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:47.869816 [ 3333 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:48.581887 [ 22694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:48.871419 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:49.413572 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:49.889390 [ 3449 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:50.373423 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:50.893356 [ 3337 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:51.167555 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:51.905368 [ 3077 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:51.905685 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:52.764603 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:52.917166 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:53.035086 [ 22699 ] {3db9a591-db6e-436e-8478-6ba45d7b52a6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55064) (comment: 00700_decimal_aggregates.sql) (in query: SELECT quantiles(0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0)(a) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:18:53.036752 [ 22699 ] {3db9a591-db6e-436e-8478-6ba45d7b52a6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:18:53.346440 [ 23388 ] {897e73ee-82ca-42f6-a901-7dc8028321d9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47340) (comment: 00700_decimal_aggregates.sql) (in query: DROP DATABASE IF EXISTS test_3lkwbpwv ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:18:53.348024 [ 23388 ] {897e73ee-82ca-42f6-a901-7dc8028321d9} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:53.468441 [ 3998 ] {1a419610-bc54-471c-ae58-8ba745c6d3db} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47354) (comment: 00700_decimal_aggregates.sql) (in query: DROP DATABASE IF EXISTS test_3lkwbpwv ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:18:53.472373 [ 3998 ] {1a419610-bc54-471c-ae58-8ba745c6d3db} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:53.671755 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:53.927874 [ 3362 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:54.437503 [ 22694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:54.929264 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:55.257670 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:55.940087 [ 3083 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:56.049625 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:56.876844 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:56.947412 [ 3066 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:57.682928 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:57.948778 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:58.481242 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:58.555323 [ 22699 ] {d3726947-e76e-449f-a09e-1355c631e0dc} 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 SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37582) (comment: 00189_time_zones_long.sql) (in query: SELECT toMonday(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/IFunctionDateOrDateTime.h:0: DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000000b7a971b 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7a77da 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:18:58.556853 [ 22699 ] {d3726947-e76e-449f-a09e-1355c631e0dc} 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 SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/IFunctionDateOrDateTime.h:0: DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000000b7a971b 5. /build/contrib/llvm-project/libcxx/include/vector:547: DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7a77da 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:18:58.952460 [ 3446 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:18:59.247452 [ 22699 ] {35b0d045-73e3-4e16-91d1-ed97bfa13a0f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37582) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfWeek(toDateTime(1419800400), 0, 'Europe/Paris');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:59.248812 [ 22699 ] {35b0d045-73e3-4e16-91d1-ed97bfa13a0f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:18:59.301146 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:18:59.953905 [ 3300 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:00.079704 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:00.937800 [ 31099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:00.957526 [ 3502 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:01.739901 [ 11749 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:01.961015 [ 3357 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:02.491929 [ 22699 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:02.966646 [ 3509 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:03.333627 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:03.970305 [ 3515 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:04.129057 [ 22711 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:04.975508 [ 3459 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:05.041631 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:05.889255 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:05.982129 [ 3003 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:06.758412 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:06.760055 [ 22700 ] {5b40a806-5602-4654-b745-c5231ac9086b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02371_select_projection_normal_agg.sql) (in query: /* ddl_entry=query-0000000158 */ TRUNCATE TABLE IF EXISTS test_11.rng), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:19:06.797945 [ 22700 ] {5b40a806-5602-4654-b745-c5231ac9086b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51028) (comment: 02371_select_projection_normal_agg.sql) (in query: DROP TABLE IF EXISTS rng;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:19:06.806030 [ 22700 ] {5b40a806-5602-4654-b745-c5231ac9086b} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage GenerateRandom. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:19:06.988396 [ 3196 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:07.742255 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:07.990864 [ 3013 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:08.219037 [ 6398 ] {724931ca-e9cd-47c3-9bf5-eb2aee2af958} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: SELECT count() FROM bftest WHERE hasAll(y, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8643 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9fb10 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8ff2e 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000001101c752 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100cfe2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d620 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000110108b1 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bfdb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e59b 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bf0d 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100bbce 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116478cf 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:19:08.224336 [ 6398 ] {724931ca-e9cd-47c3-9bf5-eb2aee2af958} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8643 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9fb10 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8ff2e 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000001101c752 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100cfe2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d620 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000110108b1 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bfdb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e59b 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bf0d 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100bbce 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116478cf 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:19:08.651062 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:08.997203 [ 3325 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:09.540381 [ 6398 ] {5b703f93-fc6b-46b1-a2f6-2621d50f497b} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: -- can't use bloom_filter with `hasAll` on non-constant arguments (just like `has`) SELECT count() FROM bftest WHERE hasAll(x, materialize([1,2,3])) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.543969 [ 6398 ] {5b703f93-fc6b-46b1-a2f6-2621d50f497b} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.576020 [ 31099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:09.660568 [ 6398 ] {b8a21d64-070d-40a1-8002-80cfece41d1c} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: -- NULLs are not Ok SELECT count() FROM bftest WHERE hasAll(x, [NULL,-42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.670011 [ 6398 ] {b8a21d64-070d-40a1-8002-80cfece41d1c} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.803454 [ 6398 ] {38ae387e-ba5e-4710-b46e-27d7a770198a} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: SELECT count() FROM bftest WHERE hasAll(x, [0,NULL]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.807772 [ 6398 ] {38ae387e-ba5e-4710-b46e-27d7a770198a} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:09.990395 [ 6398 ] {4cbb66af-2380-43a3-b7ed-65d30f47e0f8} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: -- non-compatible types SELECT count() FROM bftest WHERE hasAll(x, [[123], -42]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8643 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9fb10 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8ff2e 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000001101c752 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100cfe2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d620 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000110108b1 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bfdb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e59b 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bf0d 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100bbce 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116478cf 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:19:09.995497 [ 6398 ] {4cbb66af-2380-43a3-b7ed-65d30f47e0f8} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), Int8 because some of them are Array and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000ad9752b 4. /build/src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000010cc53be 5. /build/src/DataTypes/getLeastSupertype.cpp:361: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000010cc8643 6. /build/src/DataTypes/FieldToDataType.cpp:142: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000010c9fb10 7. /build/src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x0000000010f8ff2e 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x000000001101c752 9. /build/src/Analyzer/QueryTreeBuilder.cpp:583: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100cfe2 10. /build/src/Analyzer/ListNode.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001100d620 11. /build/src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000110108b1 12. /build/src/Analyzer/QueryTreeBuilder.cpp:143: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bfdb 13. /build/src/Analyzer/QueryTreeBuilder.cpp:178: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100e59b 14. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000001100bf0d 15. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000001100bbce 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116478cf 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:19:10.002835 [ 3354 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:10.113581 [ 6398 ] {c7d4fe59-5076-4282-990b-ee947c2b555e} executeQuery: Code: 277. DB::Exception: Index `ix1` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41678) (comment: 02013_bloom_filter_hasAll.sql) (in query: SELECT count() FROM bftest WHERE hasAll(x, [toDecimal32(123, 3), 2]) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:10.123999 [ 6398 ] {c7d4fe59-5076-4282-990b-ee947c2b555e} TCPHandler: Code: 277. DB::Exception: Index `ix1` 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/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) @ 0x000000001285552a 5. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 8. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 9. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 11. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 14. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:19:10.476706 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:10.776350 [ 31099 ] {8c84f70d-a4be-47df-a867-7dd4bf494462} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59872) (comment: 02013_bloom_filter_hasAll.sql) (in query: DROP DATABASE IF EXISTS test_vsserg4b ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:10.779066 [ 31099 ] {8c84f70d-a4be-47df-a867-7dd4bf494462} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:11.007898 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:11.359628 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:12.013892 [ 3175 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:12.244540 [ 22694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:13.019077 [ 3323 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:13.126445 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:13.127364 [ 22699 ] {5a8f0bf6-970a-41d0-ab7b-8b149551347b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41664) (comment: 02540_date_column_consistent_insert_behaviour.sql) (in query: SELECT x, txt FROM 02540_date WHERE txt == 'CAST(65534 as UInt32)';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:13.132383 [ 22699 ] {5a8f0bf6-970a-41d0-ab7b-8b149551347b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=737). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:13.183278 [ 31099 ] {ddcc3400-3062-409f-9dcf-5d48191753d4} executeQuery: Code: 57. DB::Exception: Table test_ymnenp22.join already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41798) (comment: 01494_storage_join_persistency.sql) (in query: CREATE TABLE join (k UInt64, s String) ENGINE = Join(ANY, LEFT, k) SETTINGS persistent=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:13.188261 [ 31099 ] {ddcc3400-3062-409f-9dcf-5d48191753d4} TCPHandler: Code: 57. DB::Exception: Table test_ymnenp22.join already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:13.347302 [ 31099 ] {e7c832d0-2062-4c59-8e4a-2aea08333dd3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59894) (comment: 01494_storage_join_persistency.sql) (in query: DROP DATABASE IF EXISTS test_ymnenp22 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:13.356106 [ 31099 ] {e7c832d0-2062-4c59-8e4a-2aea08333dd3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:13.915122 [ 22694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:14.020655 [ 3221 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:14.726394 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:15.023838 [ 3070 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:15.378338 [ 22694 ] {b44dff99-6611-494e-b8ce-ea65dd0cad63} executeQuery: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45750) (comment: 00474_readonly_settings.sh) (in query: set output_format_json_quote_64bit_integers=0 ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000010267c4c 3. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885f07 4. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 5. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:15.392528 [ 22694 ] {b44dff99-6611-494e-b8ce-ea65dd0cad63} TCPHandler: Code: 164. DB::Exception: Cannot modify 'output_format_json_quote_64bit_integers' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000010267c4c 3. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885f07 4. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 5. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:15.471821 [ 22701 ] {01edcdbe-22d4-49ef-9d48-5684c00fed44} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45728) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: INSERT INTO table_for_rename_pk SELECT toDate('2019-10-01') + number % 3, number, number, number, toString(number), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb736 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:19:15.475291 [ 22701 ] {01edcdbe-22d4-49ef-9d48-5684c00fed44} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::InterpreterInsertQuery::execute() @ 0x00000000115fb736 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:19:15.558049 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:15.604715 [ 22703 ] {bcd9ac26-f327-4077-ad07-39cc17637132} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49672) (comment: 01213_alter_rename_primary_key_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_h1oxk40k ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157212a 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:19:15.607770 [ 22703 ] {bcd9ac26-f327-4077-ad07-39cc17637132} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/IInterpreter.cpp:0: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000011548d26 5. /build/src/Common/TypePromotion.h:26: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157212a 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:16.030770 [ 3220 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:16.338166 [ 22694 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:17.034408 [ 3486 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:17.193023 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:18.004889 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:18.035903 [ 3356 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:18.074937 [ 22703 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:18.271817 [ 29864 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:18.911425 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:19.037755 [ 3263 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:19.862953 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:20.044478 [ 3318 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:20.445475 [ 3520 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:20.830426 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:21.081280 [ 3471 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:21.450006 [ 3163 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:21.772285 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:21.926146 [ 3627 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {aea16b08-61a9-4255-9e00-8afbf0fac250::202506_60_70_2}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:22.082636 [ 3302 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:22.454090 [ 3145 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:22.632765 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:23.088421 [ 3009 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:23.458713 [ 3222 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:23.654679 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:24.093852 [ 3291 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:24.427188 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:24.461661 [ 3335 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:24.516612 [ 4197 ] {e92de31d-fb99-4675-bb9d-c0e9082025a1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51784) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_jghw67sn ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:24.517574 [ 4197 ] {e92de31d-fb99-4675-bb9d-c0e9082025a1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:24.539249 [ 29864 ] {01d7b946-6f2f-4f32-90ab-b8a52af8e752} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43522) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_jghw67sn ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:24.540228 [ 29864 ] {01d7b946-6f2f-4f32-90ab-b8a52af8e752} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:24.567288 [ 22703 ] {83da7fb3-bb3c-4041-927e-c1415e3ddc05} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43536) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_jghw67sn ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:24.570580 [ 22703 ] {83da7fb3-bb3c-4041-927e-c1415e3ddc05} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:24.623020 [ 29864 ] {740f3a27-67bb-480e-852c-27e8892bbc29} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43552) (comment: 02932_parallel_replicas_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_jghw67sn ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:24.626982 [ 29864 ] {740f3a27-67bb-480e-852c-27e8892bbc29} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:25.098510 [ 3229 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:25.263477 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:25.463167 [ 3008 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:26.101202 [ 3027 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:26.273605 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:26.479566 [ 3110 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:27.106916 [ 3516 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:27.363704 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:27.533139 [ 3187 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:28.109957 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:28.110951 [ 3218 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:28.125149 [ 29864 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:28.166109 [ 22703 ] {2029c968-2c1e-4bcb-950c-c9e23d00ff3e} executeQuery: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52964) (comment: 00575_illegal_column_exception_when_drop_depen_column.sh) (in query: ALTER TABLE test_00575 DROP COLUMN id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf874 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:28.251229 [ 22703 ] {2029c968-2c1e-4bcb-950c-c9e23d00ff3e} TCPHandler: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000121cf874 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efb1 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:28.536982 [ 3433 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:28.975308 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:29.116495 [ 3513 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:29.273348 [ 22703 ] {6b70208b-235e-4dba-ad3b-f353c59a38f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53014) (comment: 00575_illegal_column_exception_when_drop_depen_column.sh) (in query: SELECT * FROM test_00575 ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:29.284970 [ 22703 ] {6b70208b-235e-4dba-ad3b-f353c59a38f0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:29.538697 [ 3359 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:29.854778 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:30.119595 [ 3458 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:30.542271 [ 3358 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:30.768658 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:31.124353 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:31.544166 [ 3437 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:31.748781 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:32.130046 [ 3064 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:32.546531 [ 3313 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:32.725475 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:33.132002 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:33.548519 [ 3491 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:33.692724 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:34.134393 [ 3337 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:34.544570 [ 3998 ] {5c64c087-3c4a-4270-89a1-dc7ddcf67d73} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53126) (comment: 01073_bad_alter_partition.sql) (in query: ALTER TABLE merge_tree DROP PARTITION '202001-06';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000000c6c117b 5. /build/src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000c6c1093 6. /build/src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce66ca 7. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce661e 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 9. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 10. /build/src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118dac38 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127a9673 12. /build/src/Storages/MergeTree/MergeTreeData.cpp:5030: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bebfa 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:19:34.548568 [ 3998 ] {5c64c087-3c4a-4270-89a1-dc7ddcf67d73} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000000c6c117b 5. /build/src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000c6c1093 6. /build/src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce66ca 7. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce661e 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 9. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 10. /build/src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118dac38 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127a9673 12. /build/src/Storages/MergeTree/MergeTreeData.cpp:5030: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bebfa 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:19:34.550329 [ 3295 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:34.594796 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:35.121767 [ 5174 ] {ebf80adc-fef6-418a-a31d-f0d690d9d8b7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41272) (comment: 01073_bad_alter_partition.sql) (in query: DROP DATABASE IF EXISTS test_aodt7ht1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:35.127967 [ 5174 ] {ebf80adc-fef6-418a-a31d-f0d690d9d8b7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:35.136679 [ 3252 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:35.272618 [ 5788 ] {} test_aodt7ht1.merge_tree (d4c4e696-6232-45a7-b4ea-24cf3a32dee3): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.06.25 16:19:35.414699 [ 5788 ] {} DatabaseCatalog: Cannot drop table test_aodt7ht1.merge_tree (d4c4e696-6232-45a7-b4ea-24cf3a32dee3). 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001279aba3 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000012798bc0 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000001279e914 11. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x0000000011182d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000001118aa71 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010404f5a 14. /build/contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x000000000cba7757 15. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 16. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 17. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:35.555275 [ 3466 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:35.591511 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:36.142234 [ 3054 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:36.488983 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:36.557400 [ 3359 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:37.145056 [ 3177 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:37.272217 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:37.561408 [ 3105 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:38.062950 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:38.160593 [ 3149 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:38.566027 [ 3465 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:39.007366 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:39.165121 [ 3206 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:39.568004 [ 3437 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:40.028096 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:40.167685 [ 3213 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:40.578979 [ 3415 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:40.927467 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:41.199950 [ 3048 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:41.499949 [ 6985 ] {f1d1ce62-d941-4dc4-ae5c-d2e577c7e0da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47880) (comment: 02863_decode_html_component.sql) (in query: SELECT decodeHTMLComponent('Hello, &a;& world');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:41.502978 [ 6985 ] {f1d1ce62-d941-4dc4-ae5c-d2e577c7e0da} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=742). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:41.582358 [ 3086 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:41.746187 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:42.204996 [ 3321 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:42.486996 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:42.585559 [ 3460 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:43.207092 [ 3276 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:43.328803 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:43.611240 [ 3019 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:44.139181 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:44.212682 [ 3490 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:44.615279 [ 3123 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:44.967627 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:45.219890 [ 3364 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:45.617208 [ 3425 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:45.865305 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:46.223292 [ 3060 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:46.627394 [ 3436 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:46.762617 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:47.225192 [ 3115 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:47.641730 [ 3375 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:47.731749 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:48.159638 [ 26622 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:48.227125 [ 3243 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:48.627215 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:48.643753 [ 3311 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:49.229997 [ 3455 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:49.544397 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:49.649778 [ 3072 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:50.237011 [ 3122 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:50.357342 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:50.655001 [ 3101 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:50.854342 [ 6985 ] {4a4fad45-717a-4e6d-9fed-5e049e8023ee} executeQuery: Code: 57. DB::Exception: Table test_aqc52j1y.replacing_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47936) (comment: 01825_replacing_vertical_merge.sql) (in query: CREATE TABLE replacing_table (`key` UInt64, `value` UInt64) ENGINE = ReplacingMergeTree ORDER BY key SETTINGS vertical_merge_algorithm_min_rows_to_activate = 0, vertical_merge_algorithm_min_columns_to_activate = 0, min_bytes_for_wide_part = 0, index_granularity = 41446, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 32, min_bytes_for_full_part_storage = 195339700, compact_parts_max_bytes_to_buffer = 279390024, compact_parts_max_granules_to_buffer = 53, compact_parts_merge_max_bytes_to_prefetch_part = 16042953, merge_max_block_size = 3386, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 24962691, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 51768, primary_key_compress_block_size = 23076), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:50.859573 [ 6985 ] {4a4fad45-717a-4e6d-9fed-5e049e8023ee} TCPHandler: Code: 57. DB::Exception: Table test_aqc52j1y.replacing_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:51.239106 [ 3268 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:51.299658 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:51.463221 [ 22706 ] {77f8a503-93bc-487b-aff6-8a2d3fd5a6d5} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02343_create_empty_as_select.sql) (in query: /* ddl_entry=query-0000000181 */ CREATE TABLE test_11.t UUID '544d02c4-3afc-4716-b31c-bb884aa98885' (`1` UInt8) ENGINE = Memory EMPTY AS SELECT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:19:51.514853 [ 22706 ] {77f8a503-93bc-487b-aff6-8a2d3fd5a6d5} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59498) (comment: 02343_create_empty_as_select.sql) (in query: create table t engine=Memory empty as select 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:19:51.517474 [ 22706 ] {77f8a503-93bc-487b-aff6-8a2d3fd5a6d5} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:19:51.660384 [ 3284 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:52.200629 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:52.240648 [ 3127 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:52.326585 [ 23493 ] {ae0944c8-c123-4173-bbd5-7ab2a611b478} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59546) (comment: 03199_unbin_buffer_overflow.sh) (in query: SELECT count() FROM numbers(99) GROUP BY unhex(toFixedString(materialize('x'), 1)) WITH ROLLUP WITH TOTALS FORMAT NULL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:19:52.330209 [ 23493 ] {ae0944c8-c123-4173-bbd5-7ab2a611b478} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:19:52.664877 [ 3040 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:53.132053 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:53.242253 [ 3307 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:53.341805 [ 22706 ] {0072fe42-e965-4374-b868-29870c218428} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59526) (comment: 02184_range_hashed_dictionary_outside_range_values.sql) (in query: DROP DICTIONARY 02184_range_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:53.345738 [ 22706 ] {0072fe42-e965-4374-b868-29870c218428} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:53.435626 [ 6665 ] {b6a9fb01-833e-4274-ac43-9e13e6cd0d56} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41974) (comment: 02184_range_hashed_dictionary_outside_range_values.sql) (in query: DROP DATABASE IF EXISTS test_n6mm6uik ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:19:53.438894 [ 6665 ] {b6a9fb01-833e-4274-ac43-9e13e6cd0d56} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:53.591019 [ 23388 ] {63d9f06e-aa53-49e4-a2ba-0433c831b38c} executeQuery: Code: 390. DB::Exception: Table `not_exist_view` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59540) (comment: 01602_show_create_view.sql) (in query: SHOW CREATE VIEW test_1602.not_exist_view;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010db2227 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195b09a 6. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:53.597734 [ 23388 ] {63d9f06e-aa53-49e4-a2ba-0433c831b38c} TCPHandler: Code: 390. DB::Exception: Table `not_exist_view` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000010db2227 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195b09a 6. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:53.667219 [ 3251 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:53.676910 [ 23388 ] {9c7dc60b-8a83-41eb-ae41-32233d898915} executeQuery: Code: 36. DB::Exception: `test_1602`.`tbl` is not a VIEW. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59540) (comment: 01602_show_create_view.sql) (in query: SHOW CREATE VIEW test_1602.tbl;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195b2a7 5. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:19:53.698800 [ 23388 ] {9c7dc60b-8a83-41eb-ae41-32233d898915} TCPHandler: Code: 36. DB::Exception: `test_1602`.`tbl` is not a VIEW. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195b2a7 5. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:19:53.811416 [ 23388 ] {543a8d46-bcf9-432c-bbe2-12260e725dee} executeQuery: Code: 60. DB::Exception: Cannot resolve database name for table VIEW. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59540) (comment: 01602_show_create_view.sql) (in query: SHOW CREATE TEMPORARY VIEW;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/contrib/llvm-project/libcxx/include/optional:897: DB::Context::resolveStorageIDImpl(DB::StorageID, DB::Context::StorageNamespace, std::optional*) const @ 0x00000000110fd739 5. /build/src/Interpreters/Context.cpp:0: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcc2f 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195aec3 7. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:53.822428 [ 23388 ] {543a8d46-bcf9-432c-bbe2-12260e725dee} TCPHandler: Code: 60. DB::Exception: Cannot resolve database name for table VIEW. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/contrib/llvm-project/libcxx/include/optional:897: DB::Context::resolveStorageIDImpl(DB::StorageID, DB::Context::StorageNamespace, std::optional*) const @ 0x00000000110fd739 5. /build/src/Interpreters/Context.cpp:0: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x00000000110fcc2f 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001195aec3 7. /build/src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001195ad67 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:19:54.027629 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:54.244147 [ 3023 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:54.256124 [ 23388 ] {defe1480-818b-4580-bd23-f516d3277bcc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59540) (comment: 01602_show_create_view.sql) (in query: DROP DATABASE IF EXISTS test_1602;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:19:54.266000 [ 23388 ] {defe1480-818b-4580-bd23-f516d3277bcc} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:19:54.669200 [ 3390 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:55.121240 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:55.156149 [ 5056 ] {8f30676a-79ed-4bf6-b8e4-f7a6c5f9ff6e} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.06.25 16:19:55.163497 [ 5056 ] {8f30676a-79ed-4bf6-b8e4-f7a6c5f9ff6e} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36740) (comment: 01319_manual_write_to_replicas_long.sql) (in query: CREATE TABLE r1 (`x` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/r', 'r1') ORDER BY x SETTINGS index_granularity = 60509, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 63, min_bytes_for_full_part_storage = 472153361, compact_parts_max_bytes_to_buffer = 16146589, compact_parts_max_granules_to_buffer = 71, compact_parts_merge_max_bytes_to_prefetch_part = 10658549, merge_max_block_size = 14982, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 242731519, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7457014124, index_granularity_bytes = 6011222, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 63775, primary_key_compress_block_size = 35450), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:55.177907 [ 5056 ] {8f30676a-79ed-4bf6-b8e4-f7a6c5f9ff6e} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000010de71fd 5. /build/src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000010de8ab8 6. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de8f9c 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:55.246181 [ 3034 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:55.672578 [ 3049 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:56.009836 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:56.252236 [ 3441 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:56.679198 [ 3289 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:57.016547 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:57.263282 [ 3366 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:57.684050 [ 3483 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:57.938352 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:58.265333 [ 3330 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:58.690511 [ 3410 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:58.706222 [ 22705 ] {9412acbf-0adf-45fe-ad79-dce61adec3fa} executeQuery: Code: 57. DB::Exception: Table test_0h0owy3i.check_system_tables already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36774) (comment: 00753_system_columns_and_system_tables_long.sql) (in query: CREATE TABLE check_system_tables (key UInt8) ENGINE = Log();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:58.712191 [ 22705 ] {9412acbf-0adf-45fe-ad79-dce61adec3fa} TCPHandler: Code: 57. DB::Exception: Table test_0h0owy3i.check_system_tables already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:19:58.833068 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:19:59.280477 [ 3211 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:59.693481 [ 3205 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:19:59.731414 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:00.285747 [ 3208 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:00.598191 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:00.695183 [ 3419 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:01.294692 [ 3443 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:01.631154 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:01.707904 [ 3341 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:02.297753 [ 3307 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:02.503289 [ 5056 ] {wlxcgaqccvgk} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.019812708 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36850) (comment: 02122_join_group_by_timeout.sh) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:20:02.562746 [ 5056 ] {wlxcgaqccvgk} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.019812708 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:20:02.589976 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:02.713061 [ 3261 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:03.302328 [ 3051 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:03.530140 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:03.717600 [ 3090 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:04.307238 [ 3494 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:04.357850 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:04.416384 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_149_159_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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:04.721392 [ 3316 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:05.229627 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:05.309027 [ 3468 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:05.723398 [ 3039 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:06.029329 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:06.314093 [ 3421 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:06.729560 [ 3259 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:07.045368 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:07.328569 [ 3201 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:07.566097 [ 4370 ] {203c4509-5675-47e6-929d-fae48d32eb62} executeQuery: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34370) (comment: 02716_drop_if_empty.sql) (in query: DROP TABLE IF EMPTY data_02716_1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000115738a4 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:07.570800 [ 4370 ] {203c4509-5675-47e6-929d-fae48d32eb62} TCPHandler: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000115738a4 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:07.735002 [ 3144 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:07.966274 [ 4370 ] {d26efb15-756d-4afd-ae0e-3559d6c8924f} executeQuery: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34370) (comment: 02716_drop_if_empty.sql) (in query: DROP DATABASE IF EMPTY test_2mqqpn97_1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115757f5 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 6. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:07.977718 [ 4370 ] {d26efb15-756d-4afd-ae0e-3559d6c8924f} TCPHandler: Code: 48. DB::Exception: DROP IF EMPTY is not implemented for databases. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115757f5 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 6. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:08.018441 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:08.334330 [ 3489 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:08.741579 [ 3158 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:08.835851 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:09.342998 [ 3345 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:09.724184 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:09.746568 [ 3081 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:10.348306 [ 3241 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:10.640094 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:10.748703 [ 3128 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:11.360811 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:11.573281 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:11.750982 [ 3298 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:12.364439 [ 3392 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:12.473002 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:12.753189 [ 3041 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:13.333572 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:13.366045 [ 3121 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:13.757100 [ 3214 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:14.270343 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:14.368500 [ 3520 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:14.760979 [ 3449 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:15.192113 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:15.375432 [ 3187 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:15.762871 [ 3383 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:15.979083 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:16.377424 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:16.768342 [ 3037 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:16.875084 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:17.379561 [ 3197 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:17.768071 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:17.775222 [ 3242 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:18.228023 [ 4370 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:18.382729 [ 3266 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:18.717987 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:18.778000 [ 3352 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:19.385212 [ 3097 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:19.655436 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:19.779831 [ 3168 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:20.070730 [ 4370 ] {6a0164d7-36b8-41a5-9788-5857bee79381} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33848) (comment: 02315_readonly_create_function.sh) (in query: CREATE FUNCTION test_function AS (x) -> x + 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dac38 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d9c05 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000107e34d4 7. /build/src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000107c5fcb 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000110e2006 9. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000001197ad72 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:20:20.077572 [ 4370 ] {6a0164d7-36b8-41a5-9788-5857bee79381} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Access/ContextAccess.cpp:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000107dac38 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000107d9c05 6. /build/src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x00000000107e34d4 7. /build/src/Access/ContextAccess.cpp:0: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x00000000107c5fcb 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x00000000110e2006 9. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x000000001197ad72 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:20:20.388664 [ 3125 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:20.506743 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:20.782472 [ 3262 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:21.394626 [ 3026 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:21.451457 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:21.789007 [ 3250 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:22.397438 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:22.461458 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:22.802750 [ 3084 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:23.259952 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:23.402071 [ 3461 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:23.804552 [ 3025 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:24.069043 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:24.498483 [ 3299 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:24.808904 [ 3342 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:24.915285 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:25.502321 [ 3427 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:25.738598 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:25.811056 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:26.507750 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:26.645363 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:26.813142 [ 3217 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:27.504360 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:27.512096 [ 3372 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:27.818162 [ 3346 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:28.344584 [ 22701 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:28.514861 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:28.586239 [ 22672 ] {8357a5b4-8791-464e-8dcc-35c1f9c7e545} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.015506072 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43984) (comment: 02122_join_group_by_timeout.sh) (in query: SELECT * FROM ( SELECT a.name as n FROM ( SELECT 'Name' as name, number FROM system.numbers LIMIT 2000000 ) AS a, ( SELECT 'Name' as name2, number FROM system.numbers LIMIT 2000000 ) as b GROUP BY n ) LIMIT 20 FORMAT Null ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:28.690430 [ 22672 ] {8357a5b4-8791-464e-8dcc-35c1f9c7e545} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.015506072 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:28.824124 [ 3353 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:29.302175 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:29.519392 [ 3156 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:29.891595 [ 3154 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:30.182134 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:30.527145 [ 3033 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:30.893631 [ 3333 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:31.056278 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:31.531939 [ 3234 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:31.898019 [ 3429 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:31.964185 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:32.535263 [ 3159 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:32.889952 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:32.899983 [ 3196 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:33.540088 [ 3075 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:33.738555 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:33.902183 [ 3486 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:34.542296 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:34.729383 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:34.907215 [ 3500 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:35.544505 [ 3040 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:35.747602 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:35.909645 [ 3093 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:36.550261 [ 3444 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:36.669515 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:36.915696 [ 3056 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:37.001142 [ 22701 ] {2b7eddc8-931a-4696-bea6-1f838378ef3f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_1_59_11/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 8962): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39052) (comment: 02246_is_secure_query_log.sh) (in query: select interface, is_secure from system.query_log where query_id = '2246_test_4vmip8oj_client_nonsecure' and type = 'QueryFinish' and current_database = currentDatabase()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d65b12 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:20:37.080416 [ 22701 ] {2b7eddc8-931a-4696-bea6-1f838378ef3f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_1_59_11/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 8962): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000010d65b12 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 23. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 24. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 25. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 26. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 27. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 28. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 29. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 30. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 31. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 2025.06.25 16:20:37.191392 [ 29864 ] {224fd620-46f1-44c8-8b5b-a240b1a3db12} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60334) (comment: 01232_extremes.sql) (in query: drop database shard_1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:37.198181 [ 29864 ] {224fd620-46f1-44c8-8b5b-a240b1a3db12} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:37.555561 [ 3320 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:37.583364 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:37.918520 [ 3214 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:38.508688 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:38.557370 [ 3359 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:38.924620 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:39.476771 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:39.559419 [ 3105 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:39.926482 [ 3043 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:40.326671 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:40.339451 [ 29864 ] {f1eae5c0-ef15-4652-8249-571d3fefd673} executeQuery: Code: 57. DB::Exception: Table test_11.distr already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01232_extremes.sql) (in query: /* ddl_entry=query-0000000187 */ CREATE TABLE test_11.distr UUID '2009b8d1-0316-4aa2-9d26-766ae84173ff' (`number` UInt64) ENGINE = Distributed(test_cluster_two_shards_different_databases, '', num_01232)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:20:40.377215 [ 29864 ] {f1eae5c0-ef15-4652-8249-571d3fefd673} executeQuery: Code: 57. DB::Exception: Table test_11.distr already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39074) (comment: 01232_extremes.sql) (in query: create table distr (number UInt64) engine = Distributed(test_cluster_two_shards_different_databases, '', num_01232);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:20:40.382435 [ 29864 ] {f1eae5c0-ef15-4652-8249-571d3fefd673} TCPHandler: Code: 57. DB::Exception: Table test_11.distr already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:20:40.561778 [ 3465 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:40.928295 [ 3429 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:41.346233 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:41.563365 [ 3358 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:41.930439 [ 3239 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:42.317886 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:42.567206 [ 3035 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:42.932564 [ 3076 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:43.115077 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:43.571610 [ 3368 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:43.932101 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:43.934333 [ 3502 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:44.597300 [ 3075 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:44.833097 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:44.936121 [ 3357 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:45.601669 [ 3285 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:45.725221 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:45.938147 [ 3053 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:46.604547 [ 3351 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:46.649840 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:46.939963 [ 3459 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:47.464540 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:47.608028 [ 3518 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:47.941947 [ 3304 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:48.327314 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:48.383555 [ 26622 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:48.612228 [ 3109 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:48.946149 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:49.164128 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:49.629615 [ 3496 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:49.945768 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:49.949331 [ 3464 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:50.631781 [ 3092 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:50.809026 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:50.950773 [ 3337 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:51.634001 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:51.725759 [ 23493 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:51.955700 [ 3435 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:52.137408 [ 22706 ] {5b9c1d92-61ad-4fc6-8c0c-6d7ba7086933} executeQuery: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32946) (comment: 00800_low_cardinality_merge_join.gen.sql) (in query: SELECT * FROM (SELECT dummy AS val FROM system.one) s1 ANY LEFT JOIN (SELECT dummy AS val FROM system.one) s2 ON val + 0 = val * 1 ORDER BY val;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:20:52.142419 [ 22706 ] {5b9c1d92-61ad-4fc6-8c0c-6d7ba7086933} TCPHandler: Code: 403. DB::Exception: Cannot determine join keys in ANY LEFT JOIN ... ON (val + 0) = (val * 1). (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Planner/PlannerJoins.cpp:0: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000011683df5 5. /build/src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011680cdd 6. /build/src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001166d4ad 7. /build/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&) @ 0x0000000011662ec2 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 9. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 10. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 11. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:20:52.577046 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:52.635644 [ 3284 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:52.959718 [ 3450 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:53.437152 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:53.638505 [ 3235 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:53.966307 [ 3069 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:54.335944 [ 22706 ] {c151e23a-313a-4cbe-9c76-9d9f44272204} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:32946) (comment: 00800_low_cardinality_merge_join.gen.sql) (in query: SELECT * FROM (SELECT number AS l FROM system.numbers LIMIT 3) s1 ANY LEFT JOIN (SELECT toLowCardinality(number) AS r FROM system.numbers LIMIT 3) s2 ON l + 1 = r * 1 ORDER BY l;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:54.339082 [ 22706 ] {c151e23a-313a-4cbe-9c76-9d9f44272204} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=765, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:20:54.381944 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:54.640369 [ 3519 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:54.968198 [ 3212 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:55.182266 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:55.414545 [ 6985 ] {a165f828-ed4b-49d8-8a14-adeb0c34a1a2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00942_mv_rename_table.sql) (in query: /* ddl_entry=query-0000000197 */ DROP TABLE test_11.src_00942 SYNC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:55.432198 [ 6985 ] {a165f828-ed4b-49d8-8a14-adeb0c34a1a2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33144) (comment: 00942_mv_rename_table.sql) (in query: DROP TABLE src_00942;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:55.434492 [ 6985 ] {a165f828-ed4b-49d8-8a14-adeb0c34a1a2} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:55.641867 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:55.974606 [ 3373 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:56.100533 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:56.199215 [ 6985 ] {ceefa04e-7243-4d99-90ab-52def871fcd5} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56720) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(NULL)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.209083 [ 6985 ] {ceefa04e-7243-4d99-90ab-52def871fcd5} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.293685 [ 6985 ] {11e7e4ba-3973-45e2-8eba-c69d89b332ec} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56720) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(NULL + NULL)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.301545 [ 6985 ] {11e7e4ba-3973-45e2-8eba-c69d89b332ec} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.353812 [ 6985 ] {32f65556-cce5-4333-8ccc-a62025655af7} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56720) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray([])(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.367831 [ 6985 ] {32f65556-cce5-4333-8ccc-a62025655af7} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ef455ee 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:20:56.589410 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {aea16b08-61a9-4255-9e00-8afbf0fac250::202506_1_85_12}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:56.619618 [ 6985 ] {1fa8b9b3-320d-44a5-851a-3221e2559295} executeQuery: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual throwIf(1). In scope SELECT groupArray(throwIf(1))(number) FROM numbers(10). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56720) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: SELECT groupArray(throwIf(1))(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110524a1 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:20:56.626589 [ 6985 ] {1fa8b9b3-320d-44a5-851a-3221e2559295} TCPHandler: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual throwIf(1). In scope SELECT groupArray(throwIf(1))(number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110524a1 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:20:56.649819 [ 3246 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:56.744077 [ 6985 ] {f3295533-e14e-493f-aaf9-cb67cbdc5283} executeQuery: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual number. In scope SELECT groupArray(number)(number) FROM numbers(10). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56720) (comment: 01934_constexpr_aggregate_function_parameters.sql) (in query: -- Not the best error message, can be improved. SELECT groupArray(number)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110524a1 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:20:56.749029 [ 6985 ] {f3295533-e14e-493f-aaf9-cb67cbdc5283} TCPHandler: Code: 36. DB::Exception: Parameter for function 'groupArray' expected to have constant value. Actual number. In scope SELECT groupArray(number)(number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x000000000cb8384b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110524a1 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:20:56.770372 [ 5056 ] {e923cb5e-5b7a-4875-aca9-b57fe085fd88} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56746) (comment: 02122_parallel_formatting_Template.sh) (in query: select number as x, number + 1 as y, concat('string: ', toString(number)) as s from numbers(200000) group by number with totals order by number limit 190000 format Template SETTINGS format_template_resultset = '/usr/share/clickhouse-test/queries/0_stateless/02122_parallel_formatting_Template_test_jpeeid8h_template_format_resultset.tmp', format_template_row = '/usr/share/clickhouse-test/queries/0_stateless/02122_parallel_formatting_Template_test_jpeeid8h_template_format_row.tmp', format_template_rows_between_delimiter = ';\n'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:20:56.790333 [ 5056 ] {e923cb5e-5b7a-4875-aca9-b57fe085fd88} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:20:56.868806 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:56.978104 [ 3167 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:57.609473 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:57.654777 [ 3150 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:57.797494 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:57.983139 [ 3484 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:58.115099 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:58.297847 [ 23388 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:58.659851 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:58.696562 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:58.988145 [ 3204 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:59.113552 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:59.642368 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:20:59.661483 [ 3044 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:59.991502 [ 3095 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:20:59.991620 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:00.482497 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:00.665166 [ 3491 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:00.804902 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:00.996342 [ 3334 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:01.397326 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:01.666972 [ 3040 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:01.694876 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:01.998140 [ 3279 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:02.156203 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:02.188899 [ 5056 ] {06b4ee43-e866-454e-b8b8-be9d9283e1e5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56866) (comment: 01412_cache_dictionary_race.sh) (in query: DROP DATABASE IF EXISTS ordinary_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:02.195964 [ 5056 ] {06b4ee43-e866-454e-b8b8-be9d9283e1e5} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:02.555843 [ 23388 ] {41206acb-c779-49a4-b7da-3b2d82963dc6} executeQuery: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56868) (comment: 01412_cache_dictionary_race.sh) (in query: CREATE DATABASE ordinary_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:21:02.589088 [ 23388 ] {41206acb-c779-49a4-b7da-3b2d82963dc6} TCPHandler: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:21:02.618837 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:02.668657 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:02.969441 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:03.002190 [ 3165 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:03.057436 [ 5056 ] {24c11eb4-d84d-4e79-b0f5-6bb681f8964d} executeQuery: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56908) (comment: 01412_cache_dictionary_race.sh) (in query: CREATE DICTIONARY ordinary_db.dict1 (`key_column` UInt64 DEFAULT 0, `second_column` UInt8 DEFAULT 1, `third_column` String DEFAULT 'qqq') PRIMARY KEY key_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'view_for_dict' PASSWORD '[HIDDEN]' DB 'ordinary_db')) LIFETIME(MIN 1 MAX 3) LAYOUT(CACHE(SIZE_IN_CELLS 3))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f422 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:21:03.079004 [ 5056 ] {24c11eb4-d84d-4e79-b0f5-6bb681f8964d} TCPHandler: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f422 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:21:03.368256 [ 23388 ] {c7748ebb-5230-46a6-85c1-261b3662b651} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column type): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_81_81_0/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 74): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56896) (comment: 02246_is_secure_query_log.sh) (in query: select interface, is_secure from system.query_log where query_id = '2246_test_4vmip8oj_http_secure' and type = 'QueryFinish' and current_database = currentDatabase()), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber<_BitInt(8)>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d32a98 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 2025.06.25 16:21:03.385542 [ 23388 ] {c7748ebb-5230-46a6-85c1-261b3662b651} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column type): (while reading from part /var/lib/clickhouse/store/aea/aea16b08-61a9-4255-9e00-8afbf0fac250/202506_81_81_0/ in table system.query_log (aea16b08-61a9-4255-9e00-8afbf0fac250) located on disk default of type local, from mark 0 with max_rows_to_read = 74): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000010ba4fab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000010ba5ec9 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber<_BitInt(8)>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010d32a98 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 17. /build/src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x00000000128da069 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128efae0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e98f8 23. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 24. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 25. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 26. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 27. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 28. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 29. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 30. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 2025.06.25 16:21:03.464581 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:03.481343 [ 22705 ] {bc333c94-55f5-4139-b073-db17b282ab79} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56926) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.497005 [ 22705 ] {bc333c94-55f5-4139-b073-db17b282ab79} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.560255 [ 22700 ] {7e14bc02-8c87-4c26-ae04-c685898ad669} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56928) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.568953 [ 2956 ] {2f9e127e-7bd6-4e73-8d63-967217d98abc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56938) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.581783 [ 22700 ] {7e14bc02-8c87-4c26-ae04-c685898ad669} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.581825 [ 2956 ] {2f9e127e-7bd6-4e73-8d63-967217d98abc} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.610683 [ 5056 ] {b4d5e9a2-8c96-4098-8b8f-2d7fab130e1c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56924) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.617058 [ 5056 ] {b4d5e9a2-8c96-4098-8b8f-2d7fab130e1c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.679972 [ 3452 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:03.722569 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:03.727588 [ 4370 ] {df2d052d-2bc6-43c7-9415-58d724c373b7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56962) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.753821 [ 4370 ] {df2d052d-2bc6-43c7-9415-58d724c373b7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.817542 [ 22712 ] {e56396c0-ac64-499e-81fd-c296bded56fb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56976) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:03.831056 [ 22712 ] {e56396c0-ac64-499e-81fd-c296bded56fb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.005446 [ 3045 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:04.006768 [ 5056 ] {0a4ed474-533b-416c-a82d-f3804ab9778a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56984) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.021415 [ 5056 ] {0a4ed474-533b-416c-a82d-f3804ab9778a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.057620 [ 22705 ] {25be296f-ea96-4869-81e5-4dbf948f2a76} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56998) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.058888 [ 22700 ] {eaef3ead-a92d-4ded-b596-cda8d1446825} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57014) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.065271 [ 22705 ] {25be296f-ea96-4869-81e5-4dbf948f2a76} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.092142 [ 22700 ] {eaef3ead-a92d-4ded-b596-cda8d1446825} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.169743 [ 2956 ] {37187b93-dfb6-45a4-be46-2e3852b1d8ec} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57030) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.180326 [ 2956 ] {37187b93-dfb6-45a4-be46-2e3852b1d8ec} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.216311 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:04.276792 [ 4370 ] {19012228-ecff-4a5f-a236-65ce984b7c88} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57044) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.283605 [ 4370 ] {19012228-ecff-4a5f-a236-65ce984b7c88} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.410332 [ 5056 ] {56ec4e2f-739f-4a4d-ad8d-ec3f603993f3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57052) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.418432 [ 5056 ] {56ec4e2f-739f-4a4d-ad8d-ec3f603993f3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.436969 [ 22705 ] {6a02b7db-b361-428b-a64e-44db3af5b913} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38502) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.457156 [ 22705 ] {6a02b7db-b361-428b-a64e-44db3af5b913} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.495405 [ 2956 ] {b8f53d7f-7f03-4c94-b9eb-96d409d1dd0f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38514) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.497047 [ 2956 ] {b8f53d7f-7f03-4c94-b9eb-96d409d1dd0f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.509003 [ 6398 ] {eb8b288f-cd24-4a41-a1ab-ffdfe666f6d4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38522) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.509926 [ 22700 ] {6ace7df6-65b6-4f48-9ac9-9587177aa868} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38508) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.517144 [ 22700 ] {6ace7df6-65b6-4f48-9ac9-9587177aa868} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.537303 [ 6398 ] {eb8b288f-cd24-4a41-a1ab-ffdfe666f6d4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.571321 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:04.682678 [ 3410 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:04.731473 [ 5056 ] {8d7c2d78-0bc6-4ede-b9a8-fd2094cb5c42} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38540) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.741080 [ 5056 ] {8d7c2d78-0bc6-4ede-b9a8-fd2094cb5c42} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.791276 [ 23388 ] {49798d5b-655a-49f8-a00d-58c96aa87e81} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38556) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.814712 [ 23388 ] {49798d5b-655a-49f8-a00d-58c96aa87e81} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.856028 [ 22705 ] {fb7d0a69-394a-4aa4-98a1-a0ed5ea4d19c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38564) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.874015 [ 22705 ] {fb7d0a69-394a-4aa4-98a1-a0ed5ea4d19c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.900265 [ 6398 ] {caf36293-51d6-4a3e-853c-65e2dbde48df} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38590) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.921910 [ 6398 ] {caf36293-51d6-4a3e-853c-65e2dbde48df} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.921952 [ 2956 ] {c3ec86c9-fa6e-428d-9803-bfb5ef7b9447} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38580) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:04.925260 [ 2956 ] {c3ec86c9-fa6e-428d-9803-bfb5ef7b9447} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.006498 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:05.021440 [ 22672 ] {93c44cc5-2f99-4e5a-9e06-57a676aa19ba} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38600) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.040504 [ 22672 ] {93c44cc5-2f99-4e5a-9e06-57a676aa19ba} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.061694 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:05.212352 [ 22705 ] {4fea95dc-3bdd-4a79-a2f2-162a86f14fa0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38616) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.221668 [ 22705 ] {4fea95dc-3bdd-4a79-a2f2-162a86f14fa0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.333193 [ 22700 ] {cfab0bde-23f3-439f-867e-0fae0b279925} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38628) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.371885 [ 22700 ] {cfab0bde-23f3-439f-867e-0fae0b279925} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.386744 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:05.425605 [ 2956 ] {107a2c2f-e493-4a2b-a85d-d263bb15983f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38648) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.427522 [ 2956 ] {107a2c2f-e493-4a2b-a85d-d263bb15983f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.443994 [ 23388 ] {70294663-8b72-4dc9-87a7-7407e5ce02f9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38644) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.457142 [ 23388 ] {70294663-8b72-4dc9-87a7-7407e5ce02f9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.495841 [ 6398 ] {8981f19a-f525-495e-a282-aba402fc6449} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38658) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.509297 [ 6398 ] {8981f19a-f525-495e-a282-aba402fc6449} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.538837 [ 22705 ] {414fc6d9-bb2f-451e-adef-d3128bcef3ae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38666) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.565106 [ 22705 ] {414fc6d9-bb2f-451e-adef-d3128bcef3ae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.684225 [ 3199 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:05.819525 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:05.842550 [ 6398 ] {189cb87e-10f8-4672-8228-5c13eef5ea9e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38714) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:05.886035 [ 22712 ] {ddffc76c-eada-4a40-947e-a3422d22b545} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38690) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.888330 [ 22712 ] {ddffc76c-eada-4a40-947e-a3422d22b545} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.890117 [ 6398 ] {189cb87e-10f8-4672-8228-5c13eef5ea9e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:05.890204 [ 22700 ] {746f0247-ac66-466d-a80d-64fef528866d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38706) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.899619 [ 2956 ] {27dd55c1-6760-4c57-aeaa-c801eff9db8c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38708) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.903297 [ 22700 ] {746f0247-ac66-466d-a80d-64fef528866d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:05.936862 [ 2956 ] {27dd55c1-6760-4c57-aeaa-c801eff9db8c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.010983 [ 3387 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:06.195230 [ 22705 ] {3f1e9531-6f07-49a1-b5f9-bbd8558fd122} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38730) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.197334 [ 22703 ] {965dec3f-5d11-4474-8d6d-96e3f46a5af6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38738) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.211863 [ 22703 ] {965dec3f-5d11-4474-8d6d-96e3f46a5af6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.281305 [ 22705 ] {3f1e9531-6f07-49a1-b5f9-bbd8558fd122} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.295198 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:06.400206 [ 23388 ] {daf43601-ba82-4262-845f-12d3a182a12f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38782) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.420873 [ 23388 ] {daf43601-ba82-4262-845f-12d3a182a12f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.425494 [ 22700 ] {da8448f3-5cc9-48a4-b5be-bc0fa659b591} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38748) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.425409 [ 22712 ] {8d7e5f5e-fc43-4e24-9222-bb845cd6cd67} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38784) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.432454 [ 22700 ] {da8448f3-5cc9-48a4-b5be-bc0fa659b591} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.428856 [ 2956 ] {16e29c9f-695d-4b48-a15d-f2d4a97a918f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38756) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.445792 [ 22712 ] {8d7e5f5e-fc43-4e24-9222-bb845cd6cd67} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.458708 [ 2956 ] {16e29c9f-695d-4b48-a15d-f2d4a97a918f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.622570 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:06.702651 [ 3390 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:06.747147 [ 23388 ] {0f26fd9b-bef2-435e-b209-3400764a0e37} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38812) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.762163 [ 23388 ] {0f26fd9b-bef2-435e-b209-3400764a0e37} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.773309 [ 2956 ] {02cadc2e-8e77-448f-8a7c-d599b8734120} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38838) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.775369 [ 22705 ] {c69aba60-c913-477b-9343-b2d8e5ac3ecd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38796) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.793575 [ 22705 ] {c69aba60-c913-477b-9343-b2d8e5ac3ecd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.794022 [ 2956 ] {02cadc2e-8e77-448f-8a7c-d599b8734120} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.987289 [ 29864 ] {b8670045-bf35-4ec2-98f0-f615bc2ba2de} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38858) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:06.993192 [ 29864 ] {b8670045-bf35-4ec2-98f0-f615bc2ba2de} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.012451 [ 3196 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:07.019037 [ 22712 ] {3ee0f148-dba4-4114-9f71-21bb26c19513} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38842) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.021362 [ 22712 ] {3ee0f148-dba4-4114-9f71-21bb26c19513} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.080497 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:07.115550 [ 22672 ] {2ae50114-97fe-41f6-8672-765f8d4a600c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38840) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.118585 [ 22672 ] {2ae50114-97fe-41f6-8672-765f8d4a600c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.288031 [ 29864 ] {a1e654e5-402d-4c21-90d8-4aa6689ed611} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38876) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.297104 [ 29864 ] {a1e654e5-402d-4c21-90d8-4aa6689ed611} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.312038 [ 2956 ] {7ac1f67a-b439-4a3c-b6c8-74e7a9d8ec67} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38864) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.381745 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:07.388966 [ 2956 ] {7ac1f67a-b439-4a3c-b6c8-74e7a9d8ec67} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.519513 [ 22672 ] {d7d63d69-ee1d-43b7-8c02-b31948453bca} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38910) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.522425 [ 22672 ] {d7d63d69-ee1d-43b7-8c02-b31948453bca} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.541227 [ 22712 ] {756ca7d9-acba-4841-ab58-ec69329b8923} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38916) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.546642 [ 3998 ] {0db7cf31-5753-479b-9e4a-12510f4a63a8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38894) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.550365 [ 22712 ] {756ca7d9-acba-4841-ab58-ec69329b8923} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.560465 [ 3998 ] {0db7cf31-5753-479b-9e4a-12510f4a63a8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.701858 [ 22703 ] {528b3ba9-25e1-46ab-aed4-3eb85b33aeba} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38924) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.709060 [ 22703 ] {528b3ba9-25e1-46ab-aed4-3eb85b33aeba} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.711004 [ 3338 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:07.821156 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:07.846795 [ 2956 ] {3a5436ce-6307-4d6c-81cf-74872f39999b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38930) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.871268 [ 2956 ] {3a5436ce-6307-4d6c-81cf-74872f39999b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.945025 [ 22672 ] {e8a297a9-ddf7-461b-abe2-300d01982d61} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38940) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:07.969144 [ 22672 ] {e8a297a9-ddf7-461b-abe2-300d01982d61} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.015010 [ 3013 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:08.069963 [ 22703 ] {352249d6-04e4-4f9d-8959-e2867e5349d5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38960) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.072687 [ 22703 ] {352249d6-04e4-4f9d-8959-e2867e5349d5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.091580 [ 22712 ] {474ed2b1-98ea-4280-815b-6e602b2bcd71} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38944) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.105425 [ 22712 ] {474ed2b1-98ea-4280-815b-6e602b2bcd71} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.127192 [ 3998 ] {eddefdf1-8cd2-4b72-91fa-f83747b550d6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38968) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.129107 [ 3998 ] {eddefdf1-8cd2-4b72-91fa-f83747b550d6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.177484 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:08.256114 [ 2956 ] {eb0bd34c-2227-4437-8e71-cab8215be8b1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38974) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.277034 [ 2956 ] {eb0bd34c-2227-4437-8e71-cab8215be8b1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.373566 [ 22712 ] {1d9c533f-af4c-4b4d-acaa-1c2e47b641e8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39006) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.381057 [ 22712 ] {1d9c533f-af4c-4b4d-acaa-1c2e47b641e8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.496133 [ 29864 ] {561f19fe-7204-49a7-bc67-a072c4e3deea} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39018) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.498576 [ 29864 ] {561f19fe-7204-49a7-bc67-a072c4e3deea} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.517176 [ 2956 ] {59a8e3b9-6a8e-4a58-860e-8635af6c7975} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39032) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.517694 [ 22672 ] {5d8b64c5-de65-4214-be33-b44abc238ad4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39014) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.524987 [ 2956 ] {59a8e3b9-6a8e-4a58-860e-8635af6c7975} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.538693 [ 22672 ] {5d8b64c5-de65-4214-be33-b44abc238ad4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.609422 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:08.636013 [ 22703 ] {b0f953e2-f991-4ce6-b4ae-2bb8b09b0ad8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39038) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.656069 [ 22703 ] {b0f953e2-f991-4ce6-b4ae-2bb8b09b0ad8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.719838 [ 3107 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:08.757343 [ 22712 ] {84556a6b-da3e-4e7e-8e37-7d0edd695bbe} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39050) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.773510 [ 22712 ] {84556a6b-da3e-4e7e-8e37-7d0edd695bbe} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.806563 [ 2956 ] {b22e4d07-224f-44c1-abbb-644e24f39f33} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39062) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.812963 [ 2956 ] {b22e4d07-224f-44c1-abbb-644e24f39f33} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:08.968660 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:09.016854 [ 3224 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:09.043510 [ 22712 ] {afcc5ed9-cb48-41a1-8970-ebdcdd35b4db} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39102) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.049209 [ 22712 ] {afcc5ed9-cb48-41a1-8970-ebdcdd35b4db} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.070164 [ 22672 ] {0f1d9f5b-a9eb-436b-9591-18313c0b872f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39080) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.087302 [ 22672 ] {0f1d9f5b-a9eb-436b-9591-18313c0b872f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.088035 [ 2956 ] {255ab805-5a71-464b-b403-2a7bf965e9fa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39090) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.089183 [ 29864 ] {34857515-bd63-48b3-a6f4-7470509e0980} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39104) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.090974 [ 2956 ] {255ab805-5a71-464b-b403-2a7bf965e9fa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.127347 [ 29864 ] {34857515-bd63-48b3-a6f4-7470509e0980} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.263901 [ 22703 ] {9aa0dd9c-c660-49dc-aaea-10b36a1e2138} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39120) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.277253 [ 22703 ] {9aa0dd9c-c660-49dc-aaea-10b36a1e2138} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.350862 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:09.453374 [ 3998 ] {b50bb448-83a7-4d26-9b83-bde736ce9a87} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39122) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.469316 [ 3998 ] {b50bb448-83a7-4d26-9b83-bde736ce9a87} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.538657 [ 29864 ] {1996e306-2826-4d4e-a7d6-ad09ba2d4d35} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39124) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.545811 [ 29864 ] {1996e306-2826-4d4e-a7d6-ad09ba2d4d35} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.612662 [ 8172 ] {16c76f6d-1d02-4477-92e4-ec9a3d6517cd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39150) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.618993 [ 8172 ] {16c76f6d-1d02-4477-92e4-ec9a3d6517cd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.661322 [ 26622 ] {28566cfe-1372-4618-9ac3-1e00655f1355} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39174) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.719878 [ 26622 ] {28566cfe-1372-4618-9ac3-1e00655f1355} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.721178 [ 3259 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:09.797455 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:09.894074 [ 22700 ] {f4aed7cf-9d34-4623-9e23-dcda4ca8b54d} executeQuery: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38832) (comment: 01139_asof_join_types.sql) (in query: select * from (select 0 as k, 'x' as v) t1 asof join (select 0 as k, 'x' as v) t2 using(k, v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/RowRefs.cpp:0: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x0000000011a20c4a 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000119e23eb 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15007]&, DB::Block const&, DB::SettingFieldNumber const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&, DB::SettingFieldNumber const&) @ 0x000000001168900b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000116858ce 8. /build/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&) @ 0x000000001166e306 9. /build/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&) @ 0x0000000011662ec2 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:21:09.894292 [ 5174 ] {c4263620-016b-409f-afde-41744f10b42e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39162) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.901866 [ 22700 ] {f4aed7cf-9d34-4623-9e23-dcda4ca8b54d} TCPHandler: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/RowRefs.cpp:0: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x0000000011a20c4a 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x00000000119e23eb 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::HashJoin* std::construct_at[abi:v15007]&, DB::Block const&, DB::SettingFieldNumber const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&, DB::SettingFieldNumber const&) @ 0x000000001168900b 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000116858ce 8. /build/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&) @ 0x000000001166e306 9. /build/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&) @ 0x0000000011662ec2 10. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 11. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 12. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 13. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:21:09.903615 [ 5174 ] {c4263620-016b-409f-afde-41744f10b42e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.911883 [ 22703 ] {a20b135e-0d2f-48a8-9931-3c09ff9d2af4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39184) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:09.913913 [ 22703 ] {a20b135e-0d2f-48a8-9931-3c09ff9d2af4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.011002 [ 29864 ] {5130e63b-2970-42de-a96f-27e0a9f2e471} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39194) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.019881 [ 3263 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:10.023537 [ 29864 ] {5130e63b-2970-42de-a96f-27e0a9f2e471} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.133999 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:10.164791 [ 8172 ] {578dbb25-2b6d-42bb-a543-aba84fd568bf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39214) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.169241 [ 8172 ] {578dbb25-2b6d-42bb-a543-aba84fd568bf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.184059 [ 3998 ] {bf1f965a-a8ff-4eb8-aa5f-01d70ec9befb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39228) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.199911 [ 3998 ] {bf1f965a-a8ff-4eb8-aa5f-01d70ec9befb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.291413 [ 22703 ] {b1ca25f3-75fe-464f-8041-3431c605a167} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39234) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.305713 [ 22703 ] {b1ca25f3-75fe-464f-8041-3431c605a167} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.388720 [ 26622 ] {6b8cf844-c209-4751-9a58-0d88987fd846} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39260) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.431417 [ 5174 ] {8365833f-c2c4-47d8-89c9-8bb967296ab4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39256) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.437175 [ 5174 ] {8365833f-c2c4-47d8-89c9-8bb967296ab4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.451907 [ 26622 ] {6b8cf844-c209-4751-9a58-0d88987fd846} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.514242 [ 3998 ] {46c0a463-6f26-405b-9caf-b9eeadaef066} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39262) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.526511 [ 3998 ] {46c0a463-6f26-405b-9caf-b9eeadaef066} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.563468 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:10.632571 [ 22706 ] {8c32f43c-e6c0-48f2-bed2-4eed5a3e1da5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39284) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.634681 [ 22706 ] {8c32f43c-e6c0-48f2-bed2-4eed5a3e1da5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.649594 [ 8172 ] {0c0d134c-495b-435d-8a55-d24d5a5fde4f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39282) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.651015 [ 8172 ] {0c0d134c-495b-435d-8a55-d24d5a5fde4f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.711529 [ 26622 ] {b30adf56-32cb-4bd3-93f8-5ac552a5cef4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39306) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.722756 [ 3403 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:10.727161 [ 26622 ] {b30adf56-32cb-4bd3-93f8-5ac552a5cef4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.900965 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:10.936809 [ 3998 ] {12338000-685f-4f0f-91d8-f51e406c4ca8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.941741 [ 3998 ] {12338000-685f-4f0f-91d8-f51e406c4ca8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.967884 [ 29864 ] {3573970d-2648-4a33-b602-6bd4e150dbe8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39308) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.955298 [ 8172 ] {5fa7d2f7-2501-40d9-b85e-08a37830ea03} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39328) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:10.977029 [ 8172 ] {5fa7d2f7-2501-40d9-b85e-08a37830ea03} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.005108 [ 29864 ] {3573970d-2648-4a33-b602-6bd4e150dbe8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.034048 [ 3512 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:11.160554 [ 5174 ] {ebbde9a6-5416-4572-b081-a8b087288976} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39342) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.165317 [ 5174 ] {ebbde9a6-5416-4572-b081-a8b087288976} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.187389 [ 22706 ] {a44176ac-8856-44bb-9336-88e61e29209c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39356) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.195054 [ 22706 ] {a44176ac-8856-44bb-9336-88e61e29209c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.214466 [ 26622 ] {1e6cd8e4-d862-42e8-bca3-01cfa6aca8ff} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39358) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.220641 [ 26622 ] {1e6cd8e4-d862-42e8-bca3-01cfa6aca8ff} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.397725 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:11.557630 [ 26622 ] {8356de35-8f04-4c8c-878b-5485ed1f0f0c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39380) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.573042 [ 26622 ] {8356de35-8f04-4c8c-878b-5485ed1f0f0c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.715167 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:11.725563 [ 3212 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:11.883231 [ 4370 ] {b4f4a33a-06b6-4a72-9636-2128cd673f9a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39426) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.885238 [ 23388 ] {34b658db-5015-470f-a908-42cec712c895} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39430) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.895805 [ 23388 ] {34b658db-5015-470f-a908-42cec712c895} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.896100 [ 4370 ] {b4f4a33a-06b6-4a72-9636-2128cd673f9a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.896177 [ 6665 ] {45aa654a-db04-405b-ae45-e26eed9461e4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39396) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.898241 [ 22705 ] {017ab359-24b6-41aa-9337-b41581f40876} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39436) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.904343 [ 5056 ] {532035b1-699a-4672-a1e5-9b5a76b01712} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39404) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.907991 [ 22705 ] {017ab359-24b6-41aa-9337-b41581f40876} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.909560 [ 6665 ] {45aa654a-db04-405b-ae45-e26eed9461e4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:11.925118 [ 5056 ] {532035b1-699a-4672-a1e5-9b5a76b01712} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.036525 [ 3027 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:12.043294 [ 6985 ] {f9ffd4e3-2476-4505-b0f4-7f67f56e8936} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39372) (comment: 00944_minmax_null.sql) (in query: SELECT count() FROM min_max_with_nullable_string WHERE nullable_str = '.';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128beac2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bdbac 18. /build/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()() @ 0x00000000128bfb84 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c1a3f 20. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 22. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:21:12.057641 [ 6985 ] {f9ffd4e3-2476-4505-b0f4-7f67f56e8936} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000010ba5a05 15. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 16. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000128beac2 17. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x00000000128bdbac 18. /build/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()() @ 0x00000000128bfb84 19. /build/contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x00000000128c1a3f 20. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 22. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:21:12.162466 [ 26622 ] {a76fce41-2885-4839-b136-60035038611b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39452) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.179634 [ 26622 ] {a76fce41-2885-4839-b136-60035038611b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.199720 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:12.412765 [ 6665 ] {8ca9806d-688b-4fa4-bdad-f5eca5d8eebb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39478) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.424087 [ 6665 ] {8ca9806d-688b-4fa4-bdad-f5eca5d8eebb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.424140 [ 6985 ] {1fe34324-6a46-4b7e-9f32-87e72a294ae5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39464) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.432557 [ 6985 ] {1fe34324-6a46-4b7e-9f32-87e72a294ae5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.450026 [ 4370 ] {a0e18238-5517-4a90-8a88-e103240b6e32} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39492) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.461173 [ 4370 ] {a0e18238-5517-4a90-8a88-e103240b6e32} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.516352 [ 23388 ] {ef497297-d1e6-4263-9596-4664161c4f5b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39506) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.522247 [ 23388 ] {ef497297-d1e6-4263-9596-4664161c4f5b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.541118 [ 5056 ] {82adc589-33b0-4939-b679-320028bd41c8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39510) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.557052 [ 5056 ] {82adc589-33b0-4939-b679-320028bd41c8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.564379 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:12.727211 [ 3228 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:12.778417 [ 22705 ] {d82e5c19-f65f-4df4-b191-bb1e9c185486} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39526) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.785074 [ 22705 ] {d82e5c19-f65f-4df4-b191-bb1e9c185486} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.927323 [ 6985 ] {0793a2f5-6ebc-4d79-b95f-d0c94ed3d021} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39552) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.937283 [ 6985 ] {0793a2f5-6ebc-4d79-b95f-d0c94ed3d021} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.953860 [ 5056 ] {15cea49f-ec82-461b-ae34-d8ddc54329b3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39566) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.957372 [ 5056 ] {15cea49f-ec82-461b-ae34-d8ddc54329b3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.981831 [ 4370 ] {11a14136-d5d4-4f5b-8975-098b8a53f746} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39574) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.997096 [ 23388 ] {1936047a-ed00-48d6-b08e-33edf8798836} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39580) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:12.998404 [ 23388 ] {1936047a-ed00-48d6-b08e-33edf8798836} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.019569 [ 4370 ] {11a14136-d5d4-4f5b-8975-098b8a53f746} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.025316 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:13.030239 [ 22700 ] {b1d3b56f-66f5-4623-a6f4-460666ecbd98} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39586) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.039023 [ 3479 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:13.054106 [ 22700 ] {b1d3b56f-66f5-4623-a6f4-460666ecbd98} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.319252 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:13.335900 [ 5056 ] {8e3f277d-ddb2-4a1c-863f-4097a1cf7038} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39618) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.353299 [ 5056 ] {8e3f277d-ddb2-4a1c-863f-4097a1cf7038} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.356205 [ 6985 ] {f8c4d61f-524a-4392-a726-80956b4eb759} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39604) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.376828 [ 6985 ] {f8c4d61f-524a-4392-a726-80956b4eb759} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.485528 [ 23388 ] {73aa5e3b-d9a6-4e31-8b41-60fb85968701} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39640) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.489250 [ 23388 ] {73aa5e3b-d9a6-4e31-8b41-60fb85968701} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.551682 [ 22705 ] {e0f873a7-7162-4257-93ac-d22c552d3aab} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39652) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.551866 [ 22700 ] {d1eba650-b4ba-48fb-b112-c3b01c686ad3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39664) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.557288 [ 22705 ] {e0f873a7-7162-4257-93ac-d22c552d3aab} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.567553 [ 22700 ] {d1eba650-b4ba-48fb-b112-c3b01c686ad3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.585940 [ 4370 ] {963b7add-2eec-49cf-a4be-e967a3cfe6a1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39632) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.622157 [ 4370 ] {963b7add-2eec-49cf-a4be-e967a3cfe6a1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.730140 [ 3176 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:13.786862 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:13.811717 [ 2956 ] {733f5bc6-3ba4-4c93-8137-be8e7c8e2ada} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39684) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.817322 [ 2956 ] {733f5bc6-3ba4-4c93-8137-be8e7c8e2ada} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.938913 [ 22700 ] {a2c4fce3-ee62-41c6-b942-801ed4996311} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39692) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.952050 [ 22700 ] {a2c4fce3-ee62-41c6-b942-801ed4996311} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.959012 [ 22672 ] {2e06902e-5c7f-42a7-96fd-50f85df18f61} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39696) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:13.973468 [ 22672 ] {2e06902e-5c7f-42a7-96fd-50f85df18f61} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.042361 [ 3018 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:14.077693 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:14.115092 [ 6398 ] {42dfab15-afb4-4eaa-8d1c-4a79827d63ac} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39730) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.123841 [ 6398 ] {42dfab15-afb4-4eaa-8d1c-4a79827d63ac} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.132964 [ 22712 ] {c0a88ac3-b7fe-49e5-a625-4c98412a6465} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39724) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.185213 [ 22712 ] {c0a88ac3-b7fe-49e5-a625-4c98412a6465} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.254720 [ 2956 ] {6cdcbf1a-4916-470f-84d5-58c6dc173067} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39742) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.331760 [ 2956 ] {6cdcbf1a-4916-470f-84d5-58c6dc173067} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.390795 [ 22672 ] {9b544f4a-5867-492f-8f64-ef5b9da67db5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39770) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.403285 [ 22672 ] {9b544f4a-5867-492f-8f64-ef5b9da67db5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.541172 [ 22712 ] {8d439078-13b7-4ead-be8f-eb2a706b31a0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42550) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.550973 [ 22700 ] {88f8bf6e-8e52-4c76-8e0f-dc6c3516e395} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42546) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.557002 [ 22712 ] {8d439078-13b7-4ead-be8f-eb2a706b31a0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.575763 [ 22700 ] {88f8bf6e-8e52-4c76-8e0f-dc6c3516e395} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.599863 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:14.696600 [ 29864 ] {33978bb2-5c73-4de9-b428-edb04936ce87} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42560) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.731858 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:14.813559 [ 29864 ] {33978bb2-5c73-4de9-b428-edb04936ce87} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.883048 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:14.888685 [ 2956 ] {df8ae1e7-ceb4-4935-904f-7ea83cd0ff4a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42562) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:14.907995 [ 2956 ] {df8ae1e7-ceb4-4935-904f-7ea83cd0ff4a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.024883 [ 22700 ] {5a821467-6b48-4a52-9279-2e704e74d086} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42586) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.026782 [ 22700 ] {5a821467-6b48-4a52-9279-2e704e74d086} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.042799 [ 22712 ] {8d86b216-6b19-4f7c-9974-7aaecdf55b17} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42612) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.046107 [ 22712 ] {8d86b216-6b19-4f7c-9974-7aaecdf55b17} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.051470 [ 3203 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:15.135501 [ 6398 ] {89bc2789-e6d8-4f78-91c4-a0c32b4a2dd5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42628) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.151949 [ 6398 ] {89bc2789-e6d8-4f78-91c4-a0c32b4a2dd5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.152892 [ 22672 ] {0a02c987-d71f-4bf6-a209-ea067dd8eb62} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42602) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.156318 [ 22672 ] {0a02c987-d71f-4bf6-a209-ea067dd8eb62} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.298723 [ 2956 ] {bfa6740c-7a33-482b-a699-d6e06ddf9257} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42636) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.310634 [ 2956 ] {bfa6740c-7a33-482b-a699-d6e06ddf9257} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.359731 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:15.384965 [ 22700 ] {ac89b75b-e620-49a3-86c1-4ff15e847c44} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42648) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.391914 [ 22700 ] {ac89b75b-e620-49a3-86c1-4ff15e847c44} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.427162 [ 22672 ] {9aee2388-b449-45c9-bd08-5a43e3b6f77e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42662) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.429145 [ 22672 ] {9aee2388-b449-45c9-bd08-5a43e3b6f77e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.510156 [ 2956 ] {b3947a7f-e557-4aa1-b093-f4a5532bc9d0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42696) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.535368 [ 2956 ] {b3947a7f-e557-4aa1-b093-f4a5532bc9d0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.541031 [ 22712 ] {fb0c58ee-2b13-47bb-91cc-c0fc11af8feb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42664) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.565505 [ 22712 ] {fb0c58ee-2b13-47bb-91cc-c0fc11af8feb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.667096 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:15.683840 [ 6398 ] {716d5307-c028-47e0-879e-eaa9aae68461} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42716) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.689222 [ 6398 ] {716d5307-c028-47e0-879e-eaa9aae68461} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.700811 [ 22700 ] {a40d1c79-196c-4c09-93af-20d6bcd3fe13} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42700) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.727619 [ 22700 ] {a40d1c79-196c-4c09-93af-20d6bcd3fe13} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.733326 [ 3031 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:15.836476 [ 22712 ] {d9fd2bca-e6fe-46e4-89bb-c53bb78dc46b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42724) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.842512 [ 22712 ] {d9fd2bca-e6fe-46e4-89bb-c53bb78dc46b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.908394 [ 29864 ] {fd1e9b0f-c76b-438e-8aab-dd6cd8359aae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42726) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.910231 [ 29864 ] {fd1e9b0f-c76b-438e-8aab-dd6cd8359aae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.923291 [ 3998 ] {fcdf4858-dd78-4152-a15f-a52715c3d095} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42740) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:15.933203 [ 3998 ] {fcdf4858-dd78-4152-a15f-a52715c3d095} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.024065 [ 22703 ] {afad2b04-611b-47bd-859c-eae03c0fe83f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42732) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.052618 [ 3064 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:16.053027 [ 22703 ] {afad2b04-611b-47bd-859c-eae03c0fe83f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.145508 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:16.183485 [ 29864 ] {04b65e2d-edf1-4b62-95ef-8117ed227873} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42764) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:16.213377 [ 29864 ] {04b65e2d-edf1-4b62-95ef-8117ed227873} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:16.222811 [ 22712 ] {d2e8255e-e36c-4612-ab5c-b3362529ef53} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42754) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.236916 [ 22712 ] {d2e8255e-e36c-4612-ab5c-b3362529ef53} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.318426 [ 22703 ] {a7e9e877-c28e-4c14-b6d9-d054d296b858} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42768) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.325130 [ 22703 ] {a7e9e877-c28e-4c14-b6d9-d054d296b858} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.340460 [ 3998 ] {03bc39a1-d61b-462a-a549-901803ca6a0b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42796) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.375455 [ 3998 ] {03bc39a1-d61b-462a-a549-901803ca6a0b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.409110 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:16.444280 [ 5174 ] {0b885f08-092d-410b-b726-cc71be001b00} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42810) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.451387 [ 5174 ] {0b885f08-092d-410b-b726-cc71be001b00} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.524171 [ 22712 ] {fa13da9b-4c54-4af3-9617-4e42b2353113} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42824) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.533872 [ 22712 ] {fa13da9b-4c54-4af3-9617-4e42b2353113} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.709114 [ 29864 ] {8d559cd1-359d-4119-b6ec-ffe0b1b880b3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42842) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.710341 [ 29864 ] {8d559cd1-359d-4119-b6ec-ffe0b1b880b3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.724887 [ 8172 ] {283371fa-cced-43b5-a6c0-29d414996b71} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42864) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.731288 [ 8172 ] {283371fa-cced-43b5-a6c0-29d414996b71} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.734550 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:16.802573 [ 22703 ] {a47eb7fe-73dd-405d-a42f-ab96686845f1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42852) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.802760 [ 22712 ] {90b27696-2211-4168-ad7f-85bfcbeae5d4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42876) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.814733 [ 22712 ] {90b27696-2211-4168-ad7f-85bfcbeae5d4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.816302 [ 22703 ] {a47eb7fe-73dd-405d-a42f-ab96686845f1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.900173 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:16.961579 [ 5174 ] {c234a573-68cf-42f4-8fee-f5c487c5f055} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42884) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.963380 [ 5174 ] {c234a573-68cf-42f4-8fee-f5c487c5f055} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.986115 [ 29864 ] {cff39cdf-5c8c-48fc-a259-8a782f78e354} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42890) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:16.989168 [ 29864 ] {cff39cdf-5c8c-48fc-a259-8a782f78e354} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.054955 [ 3006 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:17.124505 [ 22703 ] {8ded6512-9415-41bd-bf0d-7d20d047012a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42932) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.137250 [ 22703 ] {8ded6512-9415-41bd-bf0d-7d20d047012a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.139276 [ 8172 ] {8f320788-2ea2-42d2-b408-ce1284f5f75b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42942) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.145125 [ 8172 ] {8f320788-2ea2-42d2-b408-ce1284f5f75b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.166317 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:17.335575 [ 5174 ] {85887c93-f6ff-4cec-8dd6-3f90355f64dc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42950) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.343849 [ 5174 ] {85887c93-f6ff-4cec-8dd6-3f90355f64dc} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.355195 [ 29864 ] {c14f16dd-9075-4a16-9688-906d7ddcf558} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42944) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.361215 [ 29864 ] {c14f16dd-9075-4a16-9688-906d7ddcf558} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.445651 [ 22703 ] {67d15fbf-c4f8-4a00-9968-2ddbe622bcd4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42962) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.447227 [ 22703 ] {67d15fbf-c4f8-4a00-9968-2ddbe622bcd4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.548017 [ 8172 ] {3d5da973-cc13-4031-93a1-700d2a4b3704} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42970) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.569587 [ 8172 ] {3d5da973-cc13-4031-93a1-700d2a4b3704} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.618641 [ 5174 ] {2c4ef07f-74bd-45af-9e57-c1153d5f2449} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43000) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.633461 [ 5174 ] {2c4ef07f-74bd-45af-9e57-c1153d5f2449} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.644669 [ 22712 ] {2c783117-d126-408b-b1d7-df57ee9aa353} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42984) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.672049 [ 22712 ] {2c783117-d126-408b-b1d7-df57ee9aa353} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.723110 [ 22703 ] {251267e5-fc5d-4a08-a2fa-f804b07d2c7f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43010) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.725045 [ 22703 ] {251267e5-fc5d-4a08-a2fa-f804b07d2c7f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.735890 [ 3236 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:17.833981 [ 22706 ] {5755bb49-1711-42ef-ac06-b1857e8e8f5c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43022) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.845029 [ 22706 ] {5755bb49-1711-42ef-ac06-b1857e8e8f5c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:17.955222 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:17.972568 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:18.056042 [ 3106 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:18.060629 [ 26622 ] {24af4cd1-91b7-4452-8a86-d168ca64d667} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43038) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.060807 [ 6985 ] {338da969-7e04-475d-b1c4-95cdffb70954} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43050) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.077148 [ 6985 ] {338da969-7e04-475d-b1c4-95cdffb70954} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.081938 [ 26622 ] {24af4cd1-91b7-4452-8a86-d168ca64d667} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.086684 [ 4370 ] {91243808-75af-4e4b-ad58-de0f82c931d5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43078) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.110056 [ 4370 ] {91243808-75af-4e4b-ad58-de0f82c931d5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.119469 [ 22703 ] {91eab9ee-d2b4-4f67-9d0f-5967c6574d30} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43088) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.124858 [ 22703 ] {91eab9ee-d2b4-4f67-9d0f-5967c6574d30} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.129018 [ 23388 ] {71b02628-b711-4595-8543-61731763172b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43086) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.161473 [ 23388 ] {71b02628-b711-4595-8543-61731763172b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.380531 [ 3998 ] {afd11b82-7f33-449b-93cc-041e1555a610} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43094) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.385125 [ 3998 ] {afd11b82-7f33-449b-93cc-041e1555a610} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.446925 [ 22706 ] {dc1857f6-932b-4b0f-be69-484ef7c89c37} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43116) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.461303 [ 22706 ] {dc1857f6-932b-4b0f-be69-484ef7c89c37} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.472973 [ 22703 ] {011d6743-916e-4a2c-bb85-68a1190bedf3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43108) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.473062 [ 26622 ] {e2b6f871-e3a0-4e1a-887c-5d4957d9a383} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43122) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.485695 [ 26622 ] {e2b6f871-e3a0-4e1a-887c-5d4957d9a383} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.501579 [ 22703 ] {011d6743-916e-4a2c-bb85-68a1190bedf3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.552811 [ 6985 ] {e4e18e12-c744-42ee-9f15-a43c2036b7f2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43130) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.561210 [ 6985 ] {e4e18e12-c744-42ee-9f15-a43c2036b7f2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.573433 [ 5056 ] {b6c6ab15-edec-47ca-aae5-bddede3e3cc5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43144) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.577078 [ 5056 ] {b6c6ab15-edec-47ca-aae5-bddede3e3cc5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.733815 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:18.737049 [ 3297 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:18.741328 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:18.761973 [ 22703 ] {1e42856e-e142-48c3-b42f-46610d40bd0f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43152) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.772598 [ 22703 ] {1e42856e-e142-48c3-b42f-46610d40bd0f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.973309 [ 6985 ] {6ff309ee-65e5-4f2d-a5ba-16cfd44bbdb1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43188) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:18.976999 [ 6985 ] {6ff309ee-65e5-4f2d-a5ba-16cfd44bbdb1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.042921 [ 5056 ] {4884f438-a70c-46eb-a8ed-54bf6ce507ef} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43202) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.045098 [ 5056 ] {4884f438-a70c-46eb-a8ed-54bf6ce507ef} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.057768 [ 3283 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:19.065881 [ 4370 ] {5dd07963-2f01-4fd4-bf39-d65eeaba6398} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43214) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.083364 [ 4370 ] {5dd07963-2f01-4fd4-bf39-d65eeaba6398} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.136316 [ 22703 ] {a830ce21-4efd-43dd-ad0a-9fb188721b8b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43230) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.139061 [ 22706 ] {e470944c-2682-4c8b-b982-77bf021d8b34} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43172) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.159295 [ 22703 ] {a830ce21-4efd-43dd-ad0a-9fb188721b8b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.165974 [ 22706 ] {e470944c-2682-4c8b-b982-77bf021d8b34} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.352742 [ 3998 ] {5f4d3b5a-a396-44ab-83c8-e0a510ab00db} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43246) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.354174 [ 3998 ] {5f4d3b5a-a396-44ab-83c8-e0a510ab00db} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.422729 [ 22703 ] {d8776454-65bf-483c-8f61-a99f927cc4a0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43256) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.438728 [ 22703 ] {d8776454-65bf-483c-8f61-a99f927cc4a0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.439298 [ 22706 ] {afe4c7c4-4427-4463-889a-a18469408e54} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43268) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.453578 [ 22706 ] {afe4c7c4-4427-4463-889a-a18469408e54} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.485654 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:19.521165 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:19.596124 [ 26622 ] {e263bbc2-11c1-442f-ade0-c5efb47b90e8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43276) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.597738 [ 26622 ] {e263bbc2-11c1-442f-ade0-c5efb47b90e8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.632525 [ 6985 ] {29ec8167-8fd1-4bed-827b-70c7ef1b43b2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43290) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.636176 [ 6985 ] {29ec8167-8fd1-4bed-827b-70c7ef1b43b2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.647310 [ 3998 ] {4ff78f4f-89a4-4cae-8436-1ffe96cc139b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43284) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.673647 [ 3998 ] {4ff78f4f-89a4-4cae-8436-1ffe96cc139b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.738174 [ 3316 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:19.876889 [ 22703 ] {40444eaa-e492-4f3c-9e06-53552c0bc3c6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43316) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.883606 [ 22703 ] {40444eaa-e492-4f3c-9e06-53552c0bc3c6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.948633 [ 22706 ] {ed10ffd3-02aa-4044-9159-d378122a85d2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43344) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.949976 [ 6985 ] {fc8d8574-493e-440f-9076-1e9bd37cdd80} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43332) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.963866 [ 6985 ] {fc8d8574-493e-440f-9076-1e9bd37cdd80} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:19.964822 [ 22706 ] {ed10ffd3-02aa-4044-9159-d378122a85d2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.061055 [ 3047 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:20.066779 [ 5056 ] {62959a18-e8c1-4335-9180-539aefab8619} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43348) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.068308 [ 5056 ] {62959a18-e8c1-4335-9180-539aefab8619} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.089976 [ 4370 ] {9699b98d-2db9-444c-8e52-928ec472c7d8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43352) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.113523 [ 4370 ] {9699b98d-2db9-444c-8e52-928ec472c7d8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.199781 [ 22703 ] {508dd522-bcc6-43db-8a2c-6a2b8c84380e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43360) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.215211 [ 22703 ] {508dd522-bcc6-43db-8a2c-6a2b8c84380e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.257788 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:20.285640 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:20.369117 [ 5056 ] {8947d7b7-8b81-431f-8548-4288759302f0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43390) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.379273 [ 5056 ] {8947d7b7-8b81-431f-8548-4288759302f0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.391484 [ 22706 ] {fe806c8e-bc33-4c76-aec1-3258b41948b5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43376) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.393818 [ 22706 ] {fe806c8e-bc33-4c76-aec1-3258b41948b5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.421538 [ 4370 ] {2650bf83-eeba-4bfa-a4ed-20ce76ad0f81} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43406) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.440756 [ 4370 ] {2650bf83-eeba-4bfa-a4ed-20ce76ad0f81} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.513452 [ 23388 ] {53f16fd5-865d-4b13-94ce-6a5c0f67562a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43444) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.520990 [ 23388 ] {53f16fd5-865d-4b13-94ce-6a5c0f67562a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.563192 [ 22703 ] {a1e13f4a-c248-4a5e-8996-c8d4ff39e7ca} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43430) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.564490 [ 22703 ] {a1e13f4a-c248-4a5e-8996-c8d4ff39e7ca} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.668303 [ 22706 ] {137904ed-4884-49df-9240-a008737e3391} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43458) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.676544 [ 22706 ] {137904ed-4884-49df-9240-a008737e3391} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.739951 [ 3113 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:20.776102 [ 22703 ] {a6bb074b-dd36-4fe2-8d4e-cf4266b95216} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43470) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.786324 [ 5056 ] {9b0d8bd0-8505-4d5f-93b7-3e6e73e54c68} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43480) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.789711 [ 22703 ] {a6bb074b-dd36-4fe2-8d4e-cf4266b95216} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.808985 [ 5056 ] {9b0d8bd0-8505-4d5f-93b7-3e6e73e54c68} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.882422 [ 4370 ] {a597648e-5919-415e-a5e0-29b52c5685bb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43492) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:20.980940 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:21.017100 [ 4370 ] {a597648e-5919-415e-a5e0-29b52c5685bb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.028837 [ 23388 ] {ce53e493-f5df-4372-92dd-b843bad9396f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43512) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.033209 [ 23388 ] {ce53e493-f5df-4372-92dd-b843bad9396f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.050521 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:21.053735 [ 22706 ] {75ff5e12-7c0a-49d9-9bae-6c8a98c380f6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43504) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.053872 [ 22703 ] {1dcfacf4-89d0-47b2-bf53-1bda33e6c328} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43526) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.057213 [ 22703 ] {1dcfacf4-89d0-47b2-bf53-1bda33e6c328} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.066147 [ 3117 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:21.074840 [ 22706 ] {75ff5e12-7c0a-49d9-9bae-6c8a98c380f6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.242413 [ 22705 ] {41127ab4-5458-44b6-80e6-f34b48c0d00c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43564) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.248814 [ 22705 ] {41127ab4-5458-44b6-80e6-f34b48c0d00c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.258843 [ 22700 ] {c2c824ca-67fd-4a0b-abdd-e300ecc3a75f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43572) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.265159 [ 22700 ] {c2c824ca-67fd-4a0b-abdd-e300ecc3a75f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.409513 [ 22703 ] {3d321c02-0449-43ab-8daf-5309a2750694} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43582) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.417041 [ 22703 ] {3d321c02-0449-43ab-8daf-5309a2750694} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.440962 [ 22706 ] {f679c186-7e41-4569-afac-c5f49c5ca41c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43592) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.445637 [ 22706 ] {f679c186-7e41-4569-afac-c5f49c5ca41c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.533456 [ 5056 ] {478e722f-301e-4ff7-a846-c03f69e9f5b5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43594) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.549034 [ 5056 ] {478e722f-301e-4ff7-a846-c03f69e9f5b5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.647312 [ 4370 ] {ecac24e9-a32a-4310-b512-20db0c0badb3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43606) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.688031 [ 22703 ] {8a27e419-8250-4ae8-a8c1-61731a6490cc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43618) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.697336 [ 22703 ] {8a27e419-8250-4ae8-a8c1-61731a6490cc} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.725410 [ 4370 ] {ecac24e9-a32a-4310-b512-20db0c0badb3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.737990 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:21.741618 [ 3107 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:21.748196 [ 22706 ] {f53a6d89-0e8f-47d2-8d5b-4f1e9b35da70} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43628) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.777326 [ 22706 ] {f53a6d89-0e8f-47d2-8d5b-4f1e9b35da70} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.795463 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:21.897494 [ 5056 ] {7e263eca-a231-48d1-804b-3af5fef740b7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43640) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.904964 [ 5056 ] {7e263eca-a231-48d1-804b-3af5fef740b7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.922570 [ 23388 ] {bdbde383-18e4-4f42-bed5-5a2cfaeee200} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43652) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:21.943404 [ 23388 ] {bdbde383-18e4-4f42-bed5-5a2cfaeee200} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.005202 [ 22703 ] {56ce1b16-edec-4266-ad8a-6e7567934a4e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43678) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.010922 [ 22703 ] {56ce1b16-edec-4266-ad8a-6e7567934a4e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.067278 [ 3471 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:22.190251 [ 2956 ] {fe5ae76f-70ee-4b01-b063-19805d117411} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43714) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.191743 [ 2956 ] {fe5ae76f-70ee-4b01-b063-19805d117411} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.206013 [ 4370 ] {e8680b39-54e0-4c27-806d-e67b0a56a118} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43696) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.218920 [ 4370 ] {e8680b39-54e0-4c27-806d-e67b0a56a118} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.248983 [ 22700 ] {b056a0cf-81af-4b19-9ce0-520581818d66} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43704) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.250814 [ 22700 ] {b056a0cf-81af-4b19-9ce0-520581818d66} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.329201 [ 22672 ] {1f833f1e-4792-4f79-9975-948ae536b4d3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43742) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.336462 [ 22672 ] {1f833f1e-4792-4f79-9975-948ae536b4d3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.351973 [ 22703 ] {f5e2c875-2b42-4801-ab39-4fcd5fe56ee2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43728) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.374077 [ 22703 ] {f5e2c875-2b42-4801-ab39-4fcd5fe56ee2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.444744 [ 4370 ] {a145be7d-eba7-4a10-a2b2-8ad71b82c97b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43754) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.465624 [ 4370 ] {a145be7d-eba7-4a10-a2b2-8ad71b82c97b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.539225 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:22.579343 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:22.594493 [ 22703 ] {0a22956e-e53a-46e0-9cb7-3b0f53dbfad0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43766) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.597118 [ 22703 ] {0a22956e-e53a-46e0-9cb7-3b0f53dbfad0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.639217 [ 22700 ] {cd1767d0-ce67-4819-b5bf-8d81dded6bd2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43774) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.663507 [ 22700 ] {cd1767d0-ce67-4819-b5bf-8d81dded6bd2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.677021 [ 2956 ] {fa1f2296-d05f-481c-9f35-0b63bba67d91} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43786) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.693281 [ 2956 ] {fa1f2296-d05f-481c-9f35-0b63bba67d91} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.742566 [ 3259 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:22.771149 [ 22672 ] {221704ff-556c-4b36-b73b-2e3d0b793c75} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43820) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.772870 [ 22672 ] {221704ff-556c-4b36-b73b-2e3d0b793c75} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.888506 [ 6398 ] {63c5ebe5-7a98-4c69-aa4f-9d74f7937750} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43836) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.899787 [ 6398 ] {63c5ebe5-7a98-4c69-aa4f-9d74f7937750} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.959544 [ 22703 ] {114a97fe-5dbb-4978-8610-b0b8e2ffbf4e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43842) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:22.979187 [ 22703 ] {114a97fe-5dbb-4978-8610-b0b8e2ffbf4e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.074072 [ 3071 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:23.078500 [ 2956 ] {ec325868-727a-46da-b7b7-283b83c99157} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43886) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.080538 [ 2956 ] {ec325868-727a-46da-b7b7-283b83c99157} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.151117 [ 4370 ] {85b644bc-e540-4bca-b3d4-7754e456f51e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43856) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.165464 [ 4370 ] {85b644bc-e540-4bca-b3d4-7754e456f51e} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43856). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:23.166393 [ 4370 ] {85b644bc-e540-4bca-b3d4-7754e456f51e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.168071 [ 4370 ] {85b644bc-e540-4bca-b3d4-7754e456f51e} TCPHandler: Client has gone away. 2025.06.25 16:21:23.209331 [ 22700 ] {e319b91f-367c-416c-be20-007bcd59475d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43870) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.221376 [ 22700 ] {e319b91f-367c-416c-be20-007bcd59475d} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43870). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:23.226858 [ 22700 ] {e319b91f-367c-416c-be20-007bcd59475d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.232611 [ 22700 ] {e319b91f-367c-416c-be20-007bcd59475d} TCPHandler: Client has gone away. 2025.06.25 16:21:23.312864 [ 22703 ] {390b0ced-fea4-4262-bdf5-7eb433cbd3c8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43896) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.322039 [ 22703 ] {390b0ced-fea4-4262-bdf5-7eb433cbd3c8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:43896). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:23.328584 [ 22703 ] {390b0ced-fea4-4262-bdf5-7eb433cbd3c8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000010c2226b 4. /build/src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000010c22038 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000012fbe4d0 6. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 7. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 13. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 14. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 15. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x000000001150f25f 18. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000001151a688 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000001151725c 20. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001151ce74 21. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:23.333638 [ 22703 ] {390b0ced-fea4-4262-bdf5-7eb433cbd3c8} TCPHandler: Client has gone away. 2025.06.25 16:21:23.361330 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:23.395741 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:23.423954 [ 22700 ] {ecba2a5f-5325-444f-91a1-b22a5814f700} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43910) (comment: 01412_cache_dictionary_race.sh) (in query: DROP DATABASE IF EXISTS ordinary_db), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:23.437011 [ 22700 ] {ecba2a5f-5325-444f-91a1-b22a5814f700} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:23.842999 [ 3160 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:24.076110 [ 3291 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:24.321727 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:24.337855 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:24.847592 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:25.077915 [ 3229 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:25.215898 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:25.270237 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:25.851733 [ 3012 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:26.047922 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:26.073623 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:26.079408 [ 3027 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:26.861054 [ 3376 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:26.917721 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:26.952886 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:27.080834 [ 3516 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:27.720581 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:27.832405 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:27.865254 [ 3245 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:27.869009 [ 8172 ] {8486f9b1-fcbe-4dae-a4dd-d01b56bb7e98} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52900) (comment: 01409_topK_merge.sql) (in query: DROP DATABASE IF EXISTS test_3tn5zyer ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:21:27.871046 [ 8172 ] {8486f9b1-fcbe-4dae-a4dd-d01b56bb7e98} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:27.914666 [ 4370 ] {93c48300-9de7-44d8-a523-e4d109b7b3ce} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52914) (comment: 01409_topK_merge.sql) (in query: DROP DATABASE IF EXISTS test_3tn5zyer ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:21:27.916575 [ 4370 ] {93c48300-9de7-44d8-a523-e4d109b7b3ce} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:27.963572 [ 22672 ] {b5a84173-2d3c-431e-a8a8-75dc35588fbe} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52922) (comment: 01409_topK_merge.sql) (in query: DROP DATABASE IF EXISTS test_3tn5zyer ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:21:27.965814 [ 22672 ] {b5a84173-2d3c-431e-a8a8-75dc35588fbe} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:28.082742 [ 3018 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:28.534488 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:28.661254 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:28.867011 [ 3301 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:29.086616 [ 3456 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:29.273870 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:29.445585 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:29.869061 [ 3476 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:30.065055 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:30.087745 [ 3108 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:30.335797 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:30.392620 [ 3635 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_83_110_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:30.870443 [ 3228 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:30.893669 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:31.089887 [ 3200 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:31.164320 [ 8172 ] {5220f3d6-c8b1-4332-9841-31ff83ed6a44} executeQuery: Code: 336. DB::Exception: Ordinary database engine is deprecated (see also allow_deprecated_database_ordinary setting). (UNKNOWN_DATABASE_ENGINE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46536) (comment: 01114_database_atomic.sh) (in query: CREATE DATABASE test_d7vzvtoa_1 ENGINE=Ordinary), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseOrdinary.cpp:594: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010dd2b90 5. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 6. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:31.182746 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:31.212619 [ 8172 ] {5220f3d6-c8b1-4332-9841-31ff83ed6a44} TCPHandler: Code: 336. DB::Exception: Ordinary database engine is deprecated (see also allow_deprecated_database_ordinary setting). (UNKNOWN_DATABASE_ENGINE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Databases/DatabaseOrdinary.cpp:594: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010dd2b90 5. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 6. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:31.794269 [ 3638 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_83_110_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:31.811493 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:31.872111 [ 3161 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:32.034878 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:32.093997 [ 3191 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:32.589365 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:32.885566 [ 3134 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:32.887638 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:33.104302 [ 3175 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:33.435420 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:33.809105 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:33.887255 [ 3506 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:34.105886 [ 3064 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:34.302364 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:34.797130 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:34.899286 [ 3411 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:35.108080 [ 3406 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:35.219043 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:35.674620 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:35.738338 [ 8172 ] {201a9cc1-6885-4f95-af4b-644902774f5f} executeQuery: Code: 48. DB::Exception: Table test_d7vzvtoa_3.mt belongs to database with Ordinary engine. This engine is deprecated and is not supported in transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48180) (comment: 01114_database_atomic.sh) (in query: INSERT INTO test_d7vzvtoa_3.mt SELECT * FROM numbers(110);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/MergeTreeTransaction.cpp:0: DB::checkNotOrdinaryDatabase(std::shared_ptr const&) @ 0x00000000116d6f6a 5. /build/src/Interpreters/MergeTreeTransaction.cpp:135: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116d6599 6. /build/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*) @ 0x00000000116d6c68 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x00000000127d6399 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeSink::finishDelayedChunk() @ 0x0000000012aa9da2 9. /build/src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aab003 10. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082ff3 11. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 19. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 20. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:21:35.763988 [ 8172 ] {201a9cc1-6885-4f95-af4b-644902774f5f} TCPHandler: Code: 48. DB::Exception: Table test_d7vzvtoa_3.mt belongs to database with Ordinary engine. This engine is deprecated and is not supported in transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Interpreters/MergeTreeTransaction.cpp:0: DB::checkNotOrdinaryDatabase(std::shared_ptr const&) @ 0x00000000116d6f6a 5. /build/src/Interpreters/MergeTreeTransaction.cpp:135: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000116d6599 6. /build/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*) @ 0x00000000116d6c68 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x00000000127d6399 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeSink::finishDelayedChunk() @ 0x0000000012aa9da2 9. /build/src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000012aab003 10. /build/src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000013082ff3 11. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 15. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 19. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 20. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:21:35.907433 [ 3189 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:36.030793 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:36.110020 [ 3213 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:36.620032 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:36.895537 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:36.910102 [ 3323 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:37.115181 [ 3511 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:37.532339 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:37.676635 [ 22712 ] {e6214e40-df4e-4d8c-87aa-0065cade581a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_d7vzvtoa_1.mt' in scope SELECT n + sleepEachRow(1.5) AS col FROM test_d7vzvtoa_1.mt. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48304) (comment: 01114_database_atomic.sh) (in query: SELECT count(col), sum(col) FROM (SELECT n + sleepEachRow(1.5) AS col FROM test_d7vzvtoa_1.mt) -- 14101), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:21:37.685091 [ 22712 ] {e6214e40-df4e-4d8c-87aa-0065cade581a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_d7vzvtoa_1.mt' in scope SELECT n + sleepEachRow(1.5) AS col FROM test_d7vzvtoa_1.mt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 7. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:21:37.767029 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:37.912407 [ 3127 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:38.118038 [ 3400 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:38.457536 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:38.598328 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:38.914238 [ 3433 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:39.119862 [ 3101 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:39.243588 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:39.382360 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:39.915666 [ 3056 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:40.021027 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:40.121504 [ 3108 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:40.127372 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:40.814608 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:40.916737 [ 3506 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:40.937286 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:41.123232 [ 3200 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:41.580284 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:41.729128 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:41.918995 [ 3214 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:42.126682 [ 3339 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:42.464497 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:42.558090 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:42.710983 [ 22712 ] {e9e1b28a-1fbc-4506-9393-569ecd7120b4} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48458) (comment: 01866_split_by_regexp.sql) (in query: select splitByRegexp('+', 'a+b+c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.717298 [ 22712 ] {e9e1b28a-1fbc-4506-9393-569ecd7120b4} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: +, error: no argument for repetition operator: +. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('+', 'a+b+c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.774979 [ 22712 ] {7e6fa071-c94c-405d-a5ae-456419bfb387} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48458) (comment: 01866_split_by_regexp.sql) (in query: select splitByRegexp('?', 'a?b?c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.776996 [ 22712 ] {7e6fa071-c94c-405d-a5ae-456419bfb387} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: ?, error: no argument for repetition operator: ?. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('?', 'a?b?c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.823029 [ 22712 ] {8e4c4d12-2550-4944-bca1-4ce0c2d51f5f} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48458) (comment: 01866_split_by_regexp.sql) (in query: select splitByRegexp('(', 'a(b(c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.867808 [ 22712 ] {8e4c4d12-2550-4944-bca1-4ce0c2d51f5f} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: (, error: missing ): (. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('(', 'a(b(c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.921624 [ 3411 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:42.977083 [ 22712 ] {c8cc606c-b0a7-4741-9484-933a4776ddc2} executeQuery: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48458) (comment: 01866_split_by_regexp.sql) (in query: select splitByRegexp('[', 'a[b[c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:42.981995 [ 22712 ] {c8cc606c-b0a7-4741-9484-933a4776ddc2} TCPHandler: Code: 427. DB::Exception: OptimizedRegularExpression: cannot compile re2: [, error: missing ]: [. Look at https://github.com/google/re2/wiki/Syntax for reference. Please note that if you specify regex as an SQL string literal, the slashes have to be additionally escaped. For example, to match an opening brace, write '\(' -- the first slash is for SQL and the second one is for regex: In scope SELECT splitByRegexp('[', 'a[b[c'). (CANNOT_COMPILE_REGEXP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000701d86b 4. /build/src/Common/OptimizedRegularExpression.cpp:0: OptimizedRegularExpression::OptimizedRegularExpression(String const&, int) @ 0x000000000c670123 5. /build/contrib/llvm-project/libcxx/include/string:1624: DB::(anonymous namespace)::SplitByRegexpOverloadResolver::buildImpl(std::vector> const&, std::shared_ptr const&) const @ 0x000000000b62b574 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1cc 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:21:43.130426 [ 3209 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:43.309225 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:43.392631 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:43.788052 [ 22712 ] {c38047df-0aeb-4907-97f9-7f97292ef9fc} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48458) (comment: 01866_split_by_regexp.sql) (in query: SELECT splitByRegexp(materialize(1), NULL, 3) -- { serverError ILLEGAL_COLUMN } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000073d778b 4. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6721d 5. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 13. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:21:43.803206 [ 22712 ] {c38047df-0aeb-4907-97f9-7f97292ef9fc} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function splitByRegexp must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x00000000073d778b 4. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6721d 5. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 9. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 12. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 13. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 14. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000001164f28a 15. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 16. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 17. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:21:43.926946 [ 3267 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:44.132470 [ 3177 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:44.321429 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:44.351341 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:44.824267 [ 6985 ] {f09f8cd5-63b9-4bf1-9d3d-f9cb12a3b913} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36390) (comment: 01101_literal_column_clash.sql) (in query: with 3 as "1" select 1, "1";), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000001097746b 4. /build/src/Core/Block.cpp:36: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000010975052 5. /build/src/Core/Block.cpp:0: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000001096e3b7 6. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000001096e5d8 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000011193631 8. /build/src/Interpreters/ExpressionActions.cpp:67: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x0000000011192e90 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ExpressionActions* std::construct_at[abi:v15007](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x00000000128052f5 10. /build/src/Processors/QueryPlan/ExpressionStep.cpp:39: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013140bb9 11. /build/src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013156142 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:44.832805 [ 6985 ] {f09f8cd5-63b9-4bf1-9d3d-f9cb12a3b913} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000001097746b 4. /build/src/Core/Block.cpp:36: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000010975052 5. /build/src/Core/Block.cpp:0: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000001096e3b7 6. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000001096e5d8 7. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000011193631 8. /build/src/Interpreters/ExpressionActions.cpp:67: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x0000000011192e90 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ExpressionActions* std::construct_at[abi:v15007](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x00000000128052f5 10. /build/src/Processors/QueryPlan/ExpressionStep.cpp:39: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013140bb9 11. /build/src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013156142 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:21:44.928973 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:45.045729 [ 6985 ] {f3649a12-99c8-4ffe-b480-b9036676cfbe} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(UInt8) Nullable(size = 0, UInt8(size = 0), UInt8(size = 0)). (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36390) (comment: 01101_literal_column_clash.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/9953 select 1, * from (select 2 x) a left join (select 1, 3 y) b on y = x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000001096e1b8 5. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000001096e5d8 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcae3c 7. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 8. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 9. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 10. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000011651567 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 13. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 14. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:21:45.060006 [ 6985 ] {f3649a12-99c8-4ffe-b480-b9036676cfbe} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(UInt8) Nullable(size = 0, UInt8(size = 0), UInt8(size = 0)). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000001097714b 4. /build/src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000001096e1b8 5. /build/contrib/llvm-project/libcxx/include/vector:1629: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000001096e5d8 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcae3c 7. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000012fad832 8. /build/src/Processors/QueryPlan/ExpressionStep.cpp:20: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x00000000131409b4 9. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x00000000104c52fa 10. /build/src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000011654e1c 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000011651567 12. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 13. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 14. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 15. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 2025.06.25 16:21:45.135729 [ 3269 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:45.137606 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:45.146195 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:45.906720 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:45.930488 [ 3423 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:45.952193 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:46.037552 [ 3635 ] {923b70dd-7b26-4c83-b051-01f15737ccf2::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:46.053402 [ 3635 ] {923b70dd-7b26-4c83-b051-01f15737ccf2::all_1_1_0_2} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:46.098679 [ 6985 ] {dbc4561b-179b-401b-b377-f34491c48f5a} 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: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:36438) (comment: 02132_empty_mutation_livelock.sql) (in query: alter table a8x update number=0 WHERE number=-3;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x00000000128c206b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1fa3 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bfba 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7ce44 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:46.107674 [ 6985 ] {dbc4561b-179b-401b-b377-f34491c48f5a} 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: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x00000000128c206b 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x00000000128c1fa3 5. /build/src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000012a7bfba 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000012a7ce44 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f41b 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:46.137316 [ 3485 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:46.777597 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:46.779855 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:46.939602 [ 3083 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:47.003524 [ 5056 ] {c8ac959f-f15c-4d5c-ac36-b20ccd3ea7f1} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%m');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.006859 [ 5056 ] {c8ac959f-f15c-4d5c-ac36-b20ccd3ea7f1} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.031584 [ 5056 ] {45ad341f-60af-42cc-b33f-50ee3ad579f0} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%m');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.048442 [ 5056 ] {45ad341f-60af-42cc-b33f-50ee3ad579f0} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.106786 [ 5056 ] {5903c843-ae18-42a0-9e25-32f7607c7106} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%m');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.108979 [ 5056 ] {5903c843-ae18-42a0-9e25-32f7607c7106} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%m'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.140145 [ 3464 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:47.240030 [ 5056 ] {34c9f3df-595d-415a-a1f2-343a785119cc} executeQuery: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.241181 [ 5056 ] {34c9f3df-595d-415a-a1f2-343a785119cc} TCPHandler: Code: 41. DB::Exception: Value 0 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('00', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.255432 [ 5056 ] {6e378f87-36da-4b81-bc00-7fdf9b728ba0} executeQuery: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.256718 [ 5056 ] {6e378f87-36da-4b81-bc00-7fdf9b728ba0} TCPHandler: Code: 41. DB::Exception: Value 13 for month of year must be in the range [1, 12]: In scope SELECT parseDateTime('13', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.277715 [ 5056 ] {e78570d4-a96f-44b2-8d78-62204e1c6996} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%c');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.279878 [ 5056 ] {e78570d4-a96f-44b2-8d78-62204e1c6996} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%c'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.578024 [ 5056 ] {eac1f207-d4d1-4f57-92db-17e59388abf2} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('abc', '%b');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.583544 [ 5056 ] {eac1f207-d4d1-4f57-92db-17e59388abf2} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %b from abc because of unknown month of year short text abc: In scope SELECT parseDateTime('abc', '%b'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.584670 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:47.589787 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:47.835755 [ 5056 ] {6be64685-47e4-4cda-b2c1-1190f734ebe9} executeQuery: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('summer', '%M');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.842327 [ 5056 ] {6be64685-47e4-4cda-b2c1-1190f734ebe9} TCPHandler: Code: 41. DB::Exception: Unable to parse first part of fragment %M from summer because of unknown month of year text: sum: In scope SELECT parseDateTime('summer', '%M'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:47.941440 [ 3429 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:48.105619 [ 5056 ] {c424286d-387f-4c58-b5ac-d461619646e3} executeQuery: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('60', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.111844 [ 5056 ] {c424286d-387f-4c58-b5ac-d461619646e3} TCPHandler: Code: 41. DB::Exception: Value 60 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('60', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.141924 [ 3383 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:48.171295 [ 5056 ] {1808261d-a245-4fd4-b949-0e8dfc19b51b} executeQuery: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.177358 [ 5056 ] {1808261d-a245-4fd4-b949-0e8dfc19b51b} TCPHandler: Code: 41. DB::Exception: Value -29 for minute must be in the range [0, 59]: In scope SELECT parseDateTime('-1', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.260894 [ 5056 ] {db1cadff-69ea-4db1-aac1-ff1a3b418027} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%M', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.269910 [ 5056 ] {db1cadff-69ea-4db1-aac1-ff1a3b418027} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%M', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.363653 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:48.378319 [ 6985 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:48.425114 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:48.633338 [ 5056 ] {2a3271ba-ce48-4e64-9c4a-4b621097a23d} executeQuery: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.635606 [ 5056 ] {2a3271ba-ce48-4e64-9c4a-4b621097a23d} TCPHandler: Code: 41. DB::Exception: Value 0 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('00', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.659159 [ 5056 ] {4302db52-d0ec-41a3-96ef-459585a21880} executeQuery: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('32', '%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.661890 [ 5056 ] {4302db52-d0ec-41a3-96ef-459585a21880} TCPHandler: Code: 41. DB::Exception: Value 32 for day of month must be in the range [1, 31]: In scope SELECT parseDateTime('32', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.686912 [ 5056 ] {c464ad9d-a426-41b6-ba7f-1c03c06ac087} executeQuery: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('12345', '%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.689030 [ 5056 ] {c464ad9d-a426-41b6-ba7f-1c03c06ac087} TCPHandler: Code: 41. DB::Exception: Invalid format input 12345 is malformed at 345: In scope SELECT parseDateTime('12345', '%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.719413 [ 5056 ] {007af9e0-17e3-44f8-ac65-a579005e29d7} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('02-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.722306 [ 5056 ] {007af9e0-17e3-44f8-ac65-a579005e29d7} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 2 day_of_month: 31): In scope SELECT parseDateTime('02-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.757817 [ 5056 ] {a238cdfe-5684-4d03-809d-6cc4b9498063} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('04-31', '%m-%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.763360 [ 5056 ] {a238cdfe-5684-4d03-809d-6cc4b9498063} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2000 month: 4 day_of_month: 31): In scope SELECT parseDateTime('04-31', '%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:48.946693 [ 3239 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:49.145690 [ 3293 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:49.180585 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:49.210174 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:49.249978 [ 5056 ] {66a42d2f-fa7b-41df-922f-4051d2339b47} executeQuery: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('2001-02-29', '%Y-%m-%d');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:49.251698 [ 5056 ] {66a42d2f-fa7b-41df-922f-4051d2339b47} TCPHandler: Code: 41. DB::Exception: Invalid date, out of range (year: 2001 month: 2 day_of_month: 29): In scope SELECT parseDateTime('2001-02-29', '%Y-%m-%d'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:49.948312 [ 3502 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:49.979338 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:50.061679 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:50.147370 [ 3406 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:50.192130 [ 5056 ] {65ad978b-b963-4cf3-8c97-310ae6d2da05} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1981 366', '%Y %j');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.194909 [ 5056 ] {65ad978b-b963-4cf3-8c97-310ae6d2da05} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 1981 day of year: 366): In scope SELECT parseDateTime('1981 366', '%Y %j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.220985 [ 5056 ] {ccfa2f89-d2b7-4c4b-a59d-675f33bf63d3} executeQuery: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('367', '%j');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.222937 [ 5056 ] {ccfa2f89-d2b7-4c4b-a59d-675f33bf63d3} TCPHandler: Code: 41. DB::Exception: Value 367 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('367', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.260477 [ 5056 ] {54cba37b-51a1-4e0d-8216-a91e0387629b} executeQuery: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('000', '%j');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.262720 [ 5056 ] {54cba37b-51a1-4e0d-8216-a91e0387629b} TCPHandler: Code: 41. DB::Exception: Value 0 for day of year must be in the range [1, 366]: In scope SELECT parseDateTime('000', '%j'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.291612 [ 5056 ] {2b3b1185-b3e9-4296-8bfb-54c8f7865ee9} executeQuery: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: -- The last one is chosen if multiple day of years are supplied. select parseDateTime('2000 366 2001', '%Y %j %Y');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.294161 [ 5056 ] {2b3b1185-b3e9-4296-8bfb-54c8f7865ee9} TCPHandler: Code: 41. DB::Exception: Invalid day of year, out of range (year: 2001 day of year: 366): In scope SELECT parseDateTime('2000 366 2001', '%Y %j %Y'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.835450 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:50.845328 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:50.865905 [ 5056 ] {30691cb6-6e68-48d7-847d-67f568d22ddb} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('24', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.876266 [ 5056 ] {30691cb6-6e68-48d7-847d-67f568d22ddb} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.904045 [ 5056 ] {18f67683-9b7f-46f3-9554-fad30fe3d056} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.906197 [ 5056 ] {18f67683-9b7f-46f3-9554-fad30fe3d056} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('-1', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.916954 [ 5056 ] {f7bb4e6f-bfb4-438e-8610-0d05df1f8db2} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1234567', '%H', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.918021 [ 5056 ] {f7bb4e6f-bfb4-438e-8610-0d05df1f8db2} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%H', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:50.951634 [ 3104 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:51.148863 [ 3203 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:51.279320 [ 5056 ] {b2a167c6-6414-4993-ad68-66a8149cfb5a} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('24', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.281565 [ 5056 ] {b2a167c6-6414-4993-ad68-66a8149cfb5a} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [23, 0] if_hour_of_half_day=false and hour_starts_at_1=false: In scope SELECT parseDateTime('24', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.383641 [ 5056 ] {ff45663b-e1ea-4583-bd78-827570c048a6} executeQuery: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('-1', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.390105 [ 5056 ] {ff45663b-e1ea-4583-bd78-827570c048a6} TCPHandler: Code: 41. DB::Exception: Unable to parse fragment %k from -1 because read number failed: In scope SELECT parseDateTime('-1', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.557538 [ 5056 ] {6a373133-cd0a-46f0-8e0c-d45635709eb9} executeQuery: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('1234567', '%k', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.559394 [ 5056 ] {6a373133-cd0a-46f0-8e0c-d45635709eb9} TCPHandler: Code: 41. DB::Exception: Invalid format input 1234567 is malformed at 34567: In scope SELECT parseDateTime('1234567', '%k', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.669886 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:51.690483 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:51.916589 [ 5056 ] {91e007f7-9390-4db1-a29a-6e3f631bf5db} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.920092 [ 5056 ] {91e007f7-9390-4db1-a29a-6e3f631bf5db} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.944945 [ 5056 ] {ca99e9d5-6974-45cb-bd7e-14441cb51a8c} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.950180 [ 5056 ] {ca99e9d5-6974-45cb-bd7e-14441cb51a8c} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.952897 [ 3215 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:51.985650 [ 5056 ] {e457b12f-c826-447f-8540-e0c0d0dc3836} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%h', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:51.998359 [ 5056 ] {e457b12f-c826-447f-8540-e0c0d0dc3836} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%h', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.152513 [ 3314 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:52.508163 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:52.551975 [ 5056 ] {1ef1be16-307b-4951-8bc7-f31c8c010dee} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.559427 [ 5056 ] {1ef1be16-307b-4951-8bc7-f31c8c010dee} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.563243 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:52.592030 [ 5056 ] {9b812b34-db23-4b63-8852-32d2a417edfd} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.594514 [ 5056 ] {9b812b34-db23-4b63-8852-32d2a417edfd} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.623410 [ 5056 ] {3889a110-6bd0-4c28-b48b-8e3d8fd3040e} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%I', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.625050 [ 5056 ] {3889a110-6bd0-4c28-b48b-8e3d8fd3040e} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%I', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.822913 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {aea16b08-61a9-4255-9e00-8afbf0fac250::202506_86_91_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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:52.914960 [ 5056 ] {de6cf2ab-ef19-45dd-8259-b8ed6f98da99} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('00', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.921041 [ 5056 ] {de6cf2ab-ef19-45dd-8259-b8ed6f98da99} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('00', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.958609 [ 3370 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:52.979493 [ 5056 ] {7216e78a-4dcc-4b82-af17-5ca3edc24f07} executeQuery: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('13', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:52.981542 [ 5056 ] {7216e78a-4dcc-4b82-af17-5ca3edc24f07} TCPHandler: Code: 41. DB::Exception: Value 0 for hour must be in the range [12, 1] if_hour_of_half_day=true and hour_starts_at_1=true: In scope SELECT parseDateTime('13', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:660: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45c41 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:53.017793 [ 5056 ] {fbec91dd-1eaf-408e-b39f-32345ea50295} executeQuery: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('123456789', '%l', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:53.019175 [ 5056 ] {fbec91dd-1eaf-408e-b39f-32345ea50295} TCPHandler: Code: 41. DB::Exception: Invalid format input 123456789 is malformed at 3456789: In scope SELECT parseDateTime('123456789', '%l', 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Functions/parseDateTime.cpp:701: DB::(anonymous namespace)::FunctionParseDateTimeImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad45d12 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:21:53.155729 [ 3260 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:53.346072 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:53.372107 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:53.897463 [ 5056 ] {e3a188af-523e-4956-ac41-9f636e5bebd9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=742). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36506) (comment: 02668_parse_datetime.sql) (in query: select parseDateTime('06 PM', '%h %p', 'UTC') = toDateTime('1970-01-01 18:00:00', 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:53.908903 [ 5056 ] {e3a188af-523e-4956-ac41-9f636e5bebd9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=742). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:21:53.960738 [ 3204 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:54.162404 [ 3321 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:54.280116 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:54.361326 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:54.962638 [ 3003 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:55.050591 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:55.151836 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:55.164218 [ 3364 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:55.964612 [ 3070 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:56.000690 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:56.074332 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:56.165990 [ 3060 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:57.036920 [ 3224 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:57.038104 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:57.038282 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:57.167610 [ 3439 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:57.931015 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:57.952159 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:58.039067 [ 3450 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:58.169410 [ 3441 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:58.187941 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:58.304090 [ 23388 ] {26616912-f5c2-4dd8-b439-07dd5b38b1a6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51978) (comment: 02156_storage_merge_prewhere.sql) (in query: DROP DATABASE IF EXISTS test_lomheozd ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:21:58.308440 [ 23388 ] {26616912-f5c2-4dd8-b439-07dd5b38b1a6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:58.738544 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:58.820793 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:58.875637 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.25 16:21:58.876721 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.25 16:21:58.877620 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to mysql failed 1 times 2025.06.25 16:21:58.880062 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.25 16:21:58.880831 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.25 16:21:58.881705 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to mysql failed 2 times 2025.06.25 16:21:58.884077 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} mysqlxx::Pool: Failed to connect to MySQL (conv_main@127.0.0.1:3456 as user metrika): mysqlxx::ConnectionFailed 2025.06.25 16:21:58.884808 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to conv_main@127.0.0.1:3456 as user metrika failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0) 2025.06.25 16:21:58.885330 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} Application: Connection to mysql failed 3 times 2025.06.25 16:21:59.043080 [ 3006 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:59.151905 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} executeQuery: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x0000000016464976 5. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x0000000010eb6b9d 6. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x0000000010eb54ef 7. /build/contrib/llvm-project/libcxx/include/map:1196: DB::DatabaseMySQL::empty() const @ 0x0000000010eb506b 8. /build/contrib/llvm-project/libcxx/include/string:1624: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x0000000010eb4c9c 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x0000000010ebca63 10. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010ebabec 11. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 12. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_CREATE_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50418) (comment: 01114_mysql_database_engine_segfault.sql) (in query: CREATE DATABASE conv_main ENGINE = MySQL('127.0.0.1:3456', conv_main, 'metrika', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/MySQL/DatabaseMySQL.cpp:584: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010ebae74 5. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 6. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:59.154831 [ 22700 ] {3d8adc8d-3f51-462a-a6dc-a7e4a4d614b7} TCPHandler: Code: 501. DB::Exception: Cannot create MySQL database, because Code: 279. DB::Exception: Connections to mysql failed: conv_main@127.0.0.1:3456 as user metrika, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.0.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x0000000016464976 5. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesWithModificationTime(std::shared_ptr) const @ 0x0000000010eb6b9d 6. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: DB::DatabaseMySQL::fetchTablesIntoLocalCache(std::shared_ptr) const @ 0x0000000010eb54ef 7. /build/contrib/llvm-project/libcxx/include/map:1196: DB::DatabaseMySQL::empty() const @ 0x0000000010eb506b 8. /build/contrib/llvm-project/libcxx/include/string:1624: DB::DatabaseMySQL::DatabaseMySQL(std::shared_ptr, String const&, String const&, DB::ASTStorage const*, String const&, std::unique_ptr>, mysqlxx::PoolWithFailover&&, bool) @ 0x0000000010eb4c9c 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>, mysqlxx::PoolWithFailover, bool const&, void>(std::allocator const&, std::shared_ptr&, String const&, String const&, DB::ASTStorage*&, String&, std::unique_ptr>&&, mysqlxx::PoolWithFailover&&, bool const&) @ 0x0000000010ebca63 10. /build/src/Databases/MySQL/DatabaseMySQL.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010ebabec 11. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 12. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_CREATE_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Databases/MySQL/DatabaseMySQL.cpp:584: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000010ebae74 5. /build/src/Databases/DatabaseFactory.cpp:0: DB::DatabaseFactory::getImpl(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9eb96 6. /build/src/Databases/DatabaseFactory.cpp:112: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000010d9e60b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:316: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154abfc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:59.171500 [ 3372 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:21:59.593982 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:21:59.623175 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:00.046304 [ 3382 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:00.176073 [ 3407 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:00.430807 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:00.472300 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:01.051329 [ 3255 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:01.183398 [ 3230 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:01.328363 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:01.350360 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:02.053346 [ 3106 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:02.104292 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:02.104684 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:02.187217 [ 3435 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:02.920727 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:03.055098 [ 3283 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:03.056358 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:03.191479 [ 3385 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:03.845905 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:03.943141 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:04.056866 [ 3047 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:04.199281 [ 3170 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:04.726820 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:04.739282 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:05.061803 [ 3210 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:05.203287 [ 3321 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:05.544263 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:05.692151 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:06.063634 [ 3002 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:06.205153 [ 3166 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:06.343741 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:06.598526 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:07.066014 [ 3500 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:07.201083 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:07.207176 [ 3276 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:07.524615 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:08.069291 [ 3516 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:08.083837 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:08.209392 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:08.551901 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:09.074369 [ 3354 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:09.086347 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:09.214327 [ 3510 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:09.485333 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:09.918610 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:10.076071 [ 3164 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:10.219052 [ 3038 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:10.369498 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:10.956048 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:11.077785 [ 3209 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:11.221001 [ 3140 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:11.381908 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:11.783995 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:12.079592 [ 3177 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:12.193421 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:12.229181 [ 3115 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:12.659708 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:13.026551 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:13.081514 [ 3458 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:13.230600 [ 3243 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:13.510034 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:13.883346 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:14.083422 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:14.130226 [ 4370 ] {a0402932-8bc5-4509-880e-33b657293dff} executeQuery: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52824) (comment: 02998_operator_respect_nulls.sql) (in query: SELECT plus(1, 1) RESPECT NULLS;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x000000000c975acb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053070 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:22:14.135591 [ 4370 ] {a0402932-8bc5-4509-880e-33b657293dff} TCPHandler: Code: 62. DB::Exception: Function with name 'plus' cannot use RESPECT NULLS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, char const*&&) @ 0x000000000c975acb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011053070 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 8. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 11. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 14. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 15. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 17. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 20. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 23. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 24. ? @ 0x00007f597a7a2ac3 25. ? @ 0x00007f597a834850 2025.06.25 16:22:14.232462 [ 3379 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:14.305404 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:14.772423 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:15.085292 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:15.271905 [ 3237 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:15.305418 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:15.598842 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:16.083938 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:16.090337 [ 3431 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:16.273809 [ 3125 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:16.317272 [ 4370 ] {89bddb20-3d0d-49eb-b87a-ab6fe0fa62d1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60314) (comment: 03199_queries_with_new_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_6qixdkmh ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:22:16.320197 [ 4370 ] {89bddb20-3d0d-49eb-b87a-ab6fe0fa62d1} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:16.421415 [ 2956 ] {d3a08398-620f-4bda-8b1d-a7c1801cc684} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60324) (comment: 03199_queries_with_new_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_6qixdkmh ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:22:16.426010 [ 2956 ] {d3a08398-620f-4bda-8b1d-a7c1801cc684} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:16.428073 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:16.916274 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:17.094652 [ 3181 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:17.178344 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:17.279714 [ 3344 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:17.799545 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:18.009278 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:18.096259 [ 3244 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:18.323388 [ 3192 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:18.740453 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:18.876425 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:19.098062 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:19.234062 [ 2956 ] {bb091b54-c33d-4633-b637-1540d844fe3a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60380) (comment: 00704_arrayCumSumLimited_arrayDifference.sql) (in query: DROP DATABASE IF EXISTS test_7weixqi5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:22:19.236127 [ 2956 ] {bb091b54-c33d-4633-b637-1540d844fe3a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:19.328236 [ 3507 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:19.676078 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:19.795986 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:20.084110 [ 22672 ] {a7d6bfa4-3999-41d7-ae05-b9d6374b0aa1} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33040) (comment: 02817_group_array_moving_zero_window_size.sql) (in query: SELECT groupArrayMovingAvg ( toInt64 ( 0 ) ) ( toDecimal32 ( 1 , 1 ) );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ffd304e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:22:20.087534 [ 22672 ] {a7d6bfa4-3999-41d7-ae05-b9d6374b0aa1} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:0: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000000ffd304e 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104bcd5c 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000104bbc14 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:616: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104f741 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:22:20.102404 [ 3388 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:20.330150 [ 3313 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:20.497039 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:20.637375 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:21.112245 [ 3079 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:21.342630 [ 3489 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:21.473667 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:21.486163 [ 35998 ] {74df533f-9675-4ca8-8678-2d8e46aca323} ExternalDictionariesLoader: Could not load external dictionary 'a62481db-a7cf-460a-9529-84166ff73b11', next update is scheduled at 2025-06-25 16:22:27: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): while reading column decimal_value at /var/lib/clickhouse/store/1dc/1dc4905c-1f57-4d8b-9161-cf52fb11e447/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80da88 14. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 15. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3ff0 17. /build/src/DataTypes/Serializations/SerializationDecimalBase.cpp:64: DB::SerializationDecimalBase>>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010cf0905 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/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>>>&) @ 0x00000000124f64ce 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f59cc 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 29. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 30. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:21.503847 [ 6398 ] {74df533f-9675-4ca8-8678-2d8e46aca323} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): while reading column decimal_value at /var/lib/clickhouse/store/1dc/1dc4905c-1f57-4d8b-9161-cf52fb11e447/: While executing Log: In scope SELECT dictGet('flat_dictionary', 'decimal_value', toUInt64(1)). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33066) (comment: 01804_dictionary_decimal256_type.sql) (in query: SELECT dictGet('flat_dictionary', 'decimal_value', toUInt64(1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80da88 14. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 15. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3ff0 17. /build/src/DataTypes/Serializations/SerializationDecimalBase.cpp:64: DB::SerializationDecimalBase>>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010cf0905 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/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>>>&) @ 0x00000000124f64ce 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f59cc 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 29. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 30. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 2025.06.25 16:22:21.507672 [ 6398 ] {74df533f-9675-4ca8-8678-2d8e46aca323} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): while reading column decimal_value at /var/lib/clickhouse/store/1dc/1dc4905c-1f57-4d8b-9161-cf52fb11e447/: While executing Log: In scope SELECT dictGet('flat_dictionary', 'decimal_value', toUInt64(1)). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000104ce8cb 12. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 13. /build/src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80da88 14. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 15. /build/src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000010ba42ab 16. /build/src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x0000000010ba3ff0 17. /build/src/DataTypes/Serializations/SerializationDecimalBase.cpp:64: DB::SerializationDecimalBase>>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000010cf0905 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000010cd5bf9 19. /build/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>>>&) @ 0x00000000124f64ce 20. /build/contrib/llvm-project/libcxx/include/string:1499: DB::LogSource::generate() @ 0x00000000124f59cc 21. /build/src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x0000000012d52f97 22. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Dictionaries/FlatDictionary.cpp:500: DB::FlatDictionary::loadData() @ 0x000000000c9c9c3b 29. /build/src/Dictionaries/FlatDictionary.cpp:47: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000c9c988e 30. /build/contrib/llvm-project/libcxx/include/string:1499: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000000c9e5354 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000104b1678 2025.06.25 16:22:21.558824 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:21.614374 [ 22672 ] {c0ff2643-807d-4dbc-909c-1a760ee54df7} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60412) (comment: 01804_dictionary_decimal256_type.sql) (in query: DROP DATABASE IF EXISTS test_jumtem4b ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:22:21.622945 [ 22672 ] {c0ff2643-807d-4dbc-909c-1a760ee54df7} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:22.114437 [ 3456 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:22.354619 [ 3182 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:22.364118 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:22.489557 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:23.116163 [ 3218 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:23.228424 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:23.345478 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:23.358620 [ 3238 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:24.069647 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:24.118258 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:24.187641 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:24.360426 [ 3347 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:24.989217 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:25.120131 [ 3200 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:25.158879 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:25.362420 [ 3422 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:25.847893 [ 6398 ] {f98cdb6b-da3c-4b7f-a3f2-cf9e5b09fc54} executeQuery: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33116) (comment: 02293_h3_line.sql) (in query: SELECT h3Line(0xffffffffffffff, 0xffffffffffffff);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x00000000087ba86b 4. /build/src/Functions/h3Line.cpp:106: DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009354845 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:22:25.855474 [ 6398 ] {f98cdb6b-da3c-4b7f-a3f2-cf9e5b09fc54} TCPHandler: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x00000000087ba86b 4. /build/src/Functions/h3Line.cpp:106: DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009354845 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:22:25.962192 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:26.068832 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:26.125551 [ 3108 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:26.363968 [ 3131 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:26.915461 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:27.028910 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:27.127426 [ 3339 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:27.368146 [ 3014 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:27.892011 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:27.944793 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:28.135002 [ 3374 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:28.370014 [ 3173 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:28.597297 [ 22672 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:28.876991 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:28.896647 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:29.136412 [ 3054 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:29.231899 [ 8172 ] {facd1ed3-be3c-4f44-a8d4-9f7608a54781} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39620) (comment: 02387_analyzer_cte.sql) (in query: WITH cte_subquery AS (SELECT * FROM test_table UNION DISTINCT SELECT * FROM test_table) SELECT * FROM cte_subquery;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:22:29.248982 [ 8172 ] {facd1ed3-be3c-4f44-a8d4-9f7608a54781} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:22:29.371110 [ 3266 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:29.638231 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:29.706265 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:30.080175 [ 3998 ] {4ab4301d-b8db-472e-9143-b11e11dc4703} 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.10505.altinitytest (altinity build)) (from [::1]:39670) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.094031 [ 3998 ] {4ab4301d-b8db-472e-9143-b11e11dc4703} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.137650 [ 3513 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:30.202929 [ 3998 ] {6126174b-2d4a-479c-82f5-a2904966a84e} 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.10505.altinitytest (altinity build)) (from [::1]:39670) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.212314 [ 3998 ] {6126174b-2d4a-479c-82f5-a2904966a84e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.325546 [ 3998 ] {0ced2ffc-3dbe-46f0-87ca-5e28d8fd4c6a} 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.10505.altinitytest (altinity build)) (from [::1]:39670) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7695fc 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.351189 [ 3998 ] {0ced2ffc-3dbe-46f0-87ca-5e28d8fd4c6a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7695fc 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.372399 [ 3348 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:30.403177 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:30.499326 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:30.531018 [ 3998 ] {29700973-158f-4d11-8ca5-8ef93ad46e69} 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.10505.altinitytest (altinity build)) (from [::1]:39670) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76973c 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.541260 [ 3998 ] {29700973-158f-4d11-8ca5-8ef93ad46e69} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76973c 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:22:30.666184 [ 3998 ] {d46146cf-7e7d-4dd2-99ae-27b1303159ec} 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.10505.altinitytest (altinity build)) (from [::1]:39670) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b7688a2 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:22:30.704538 [ 3998 ] {d46146cf-7e7d-4dd2-99ae-27b1303159ec} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b7688a2 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:22:31.139212 [ 3191 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:31.255591 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:31.373528 [ 3125 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:31.383306 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:32.141183 [ 3177 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:32.224124 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:32.374917 [ 3080 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:32.392151 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:33.147156 [ 3458 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:33.205125 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:33.301114 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:33.376599 [ 3344 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:34.033004 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:34.150624 [ 3464 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:34.240943 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:34.378597 [ 3498 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:35.060076 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:35.152828 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:35.288556 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:35.389920 [ 3169 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:35.814989 [ 3998 ] {642f03b4-8b76-4386-b70d-6aeaca58ce30} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 94.33 MiB (attempt to allocate chunk of 1384512 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39790) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format JSONCompactStringsEachRowWithNames), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000c66c359 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b931 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 9. /build/src/IO/BufferWithOwnMemory.h:80: DB::ColumnCompressed::compressBuffer(void const*, unsigned long, bool) @ 0x0000000011f0dcd4 10. /build/src/Columns/ColumnFixedString.cpp:430: DB::ColumnFixedString::compress() const @ 0x0000000011f3046d 11. /build/contrib/llvm-project/libcxx/include/vector:1582: DB::QueryCache::Writer::finalizeWrite() @ 0x00000000119cbaf5 12. /build/src/Interpreters/executeQuery.cpp:1346: void std::__function::__policy_invoker::__call_impl, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x0000000011917800 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010bd5dee 14. /build/src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x0000000012cb55de 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:22:36.117643 [ 3998 ] {642f03b4-8b76-4386-b70d-6aeaca58ce30} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 94.33 MiB (attempt to allocate chunk of 1384512 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000c66c359 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b931 5. /build/src/Common/MemoryTracker.cpp:405: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000c66b5bc 6. /build/src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000c624a9d 7. /build/src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000c623284 8. /build/src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000c6ae112 9. /build/src/IO/BufferWithOwnMemory.h:80: DB::ColumnCompressed::compressBuffer(void const*, unsigned long, bool) @ 0x0000000011f0dcd4 10. /build/src/Columns/ColumnFixedString.cpp:430: DB::ColumnFixedString::compress() const @ 0x0000000011f3046d 11. /build/contrib/llvm-project/libcxx/include/vector:1582: DB::QueryCache::Writer::finalizeWrite() @ 0x00000000119cbaf5 12. /build/src/Interpreters/executeQuery.cpp:1346: void std::__function::__policy_invoker::__call_impl, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x0000000011917800 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000010bd5dee 14. /build/src/Server/TCPHandler.cpp:579: DB::TCPHandler::runImpl() @ 0x0000000012cb55de 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:22:36.155328 [ 3064 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:36.309474 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:36.340233 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:36.395264 [ 3384 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:37.157262 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:37.244326 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:37.375085 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:37.401803 [ 3226 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.163068 [ 3048 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.195396 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:38.262796 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:38.406384 [ 3363 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.492361 [ 22706 ] {17fac5f7-3116-46c5-a5c3-210895d2f3d9} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 1769472 of 78889100 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/IO/LimitReadBuffer.cpp:0: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80dc7e 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000c6cb103 7. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 8. /build/src/IO/ReadBuffer.h:106: DB::HTMLForm::MultipartReadBuffer::readLine(bool) @ 0x0000000012cd4d18 9. /build/src/Server/HTTP/HTMLForm.cpp:330: DB::HTMLForm::MultipartReadBuffer::nextImpl() @ 0x0000000012cd5072 10. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 11. /build/src/IO/ReadBuffer.h:106: DB::readHeaders(Poco::Net::MessageHeader&, DB::ReadBuffer&, unsigned long, unsigned long, unsigned long) @ 0x0000000012cda368 12. /build/src/Server/HTTP/HTMLForm.cpp:202: DB::HTMLForm::readMultipart(DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x0000000012cd3fcb 13. /build/src/Server/HTTP/HTMLForm.cpp:104: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x0000000012cd34e1 14. /build/contrib/llvm-project/libcxx/include/string:1624: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x0000000012c51a99 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c3ad 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.493209 [ 8172 ] {3f6dee0e-3ce6-46c2-a65e-72de32a0505c} DynamicQueryHandler: Code: 33. DB::Exception: Unexpected EOF, got 11665408 of 78889100 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/IO/LimitReadBuffer.cpp:0: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80dc7e 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000000c6cb103 7. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 8. /build/src/IO/ReadBuffer.h:106: DB::HTMLForm::MultipartReadBuffer::readLine(bool) @ 0x0000000012cd4d18 9. /build/src/Server/HTTP/HTMLForm.cpp:330: DB::HTMLForm::MultipartReadBuffer::nextImpl() @ 0x0000000012cd5072 10. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 11. /build/src/IO/ReadBuffer.h:106: DB::readHeaders(Poco::Net::MessageHeader&, DB::ReadBuffer&, unsigned long, unsigned long, unsigned long) @ 0x0000000012cda368 12. /build/src/Server/HTTP/HTMLForm.cpp:202: DB::HTMLForm::readMultipart(DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x0000000012cd3fcb 13. /build/src/Server/HTTP/HTMLForm.cpp:104: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x0000000012cd34e1 14. /build/contrib/llvm-project/libcxx/include/string:1624: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x0000000012c51a99 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c3ad 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 18. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 21. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 22. ? @ 0x00007f597a7a2ac3 23. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.636363 [ 22706 ] {17fac5f7-3116-46c5-a5c3-210895d2f3d9} DynamicQueryHandler: Cannot read remaining request body during exception handling: Code: 33. DB::Exception: Unexpected EOF, got 2752512 of 78889100 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/IO/LimitReadBuffer.cpp:0: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80dc7e 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/HTTP/sendExceptionToHTTPClient.cpp:65: DB::setHTTPResponseStatusAndHeadersForException(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::WriteBufferFromHTTPServerResponse*, std::shared_ptr) @ 0x0000000012cdedd3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x0000000012c4e282 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c5060e 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.637766 [ 8172 ] {3f6dee0e-3ce6-46c2-a65e-72de32a0505c} DynamicQueryHandler: Cannot read remaining request body during exception handling: Code: 33. DB::Exception: Unexpected EOF, got 11993088 of 78889100 bytes. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000007c6d36b 4. /build/src/IO/LimitReadBuffer.cpp:0: DB::LimitReadBuffer::nextImpl() @ 0x000000000c80dc7e 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/HTTP/sendExceptionToHTTPClient.cpp:65: DB::setHTTPResponseStatusAndHeadersForException(int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::WriteBufferFromHTTPServerResponse*, std::shared_ptr) @ 0x0000000012cdedd3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x0000000012c4e282 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c5060e 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.669905 [ 8172 ] {3f6dee0e-3ce6-46c2-a65e-72de32a0505c} DynamicQueryHandler: Cannot send exception to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:34596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000000c789481 4. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:0: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x0000000012cdaf54 5. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:93: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x0000000012cdb2cf 6. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x0000000012cdb54d 7. /build/src/IO/WriteBuffer.h:66: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x0000000012c4e479 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c5060e 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:38.679840 [ 22706 ] {17fac5f7-3116-46c5-a5c3-210895d2f3d9} DynamicQueryHandler: Cannot send exception to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:34612). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000000c789481 4. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:0: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x0000000012cdaf54 5. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:93: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x0000000012cdb2cf 6. /build/contrib/llvm-project/libcxx/include/__mutex_base:100: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x0000000012cdb54d 7. /build/src/IO/WriteBuffer.h:66: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x0000000012c4e479 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c5060e 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:39.141998 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:39.154680 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:39.169555 [ 3324 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:39.411404 [ 3069 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:40.006429 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:40.013201 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:40.171167 [ 3314 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:40.413444 [ 3077 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:40.890705 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:40.925890 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:41.176473 [ 3136 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:41.418529 [ 3202 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:41.785331 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:41.867652 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:42.184507 [ 3272 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:42.424462 [ 3258 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:42.705160 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:42.810141 [ 22705 ] {1b05da4c-6f65-416a-9d6d-0dde566eed9b} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _part_index, s, _partition_id, x, _part, m, _part_offset, _sample_factor, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' 's' '_part' 'x' 'm' '_part_offset' '_sample_factor' '_part_uuid' '_block_offset' 'd', maybe you meant: 's', 'x', 'm' or 'd'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50816) (comment: 00652_mergetree_mutations.sh) (in query: ALTER TABLE mutations DELETE WHERE nonexistent = 0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000001187c12a 4. /build/src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011884155 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7669 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e48e7 7. /build/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) @ 0x00000000116df034 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:22:42.911767 [ 22705 ] {1b05da4c-6f65-416a-9d6d-0dde566eed9b} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _part_index, s, _partition_id, x, _part, m, _part_offset, _sample_factor, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' 's' '_part' 'x' 'm' '_part_offset' '_sample_factor' '_part_uuid' '_block_offset' 'd', maybe you meant: 's', 'x', 'm' or 'd'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000001187c12a 4. /build/src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011884155 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7669 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e48e7 7. /build/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) @ 0x00000000116df034 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:22:43.051216 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:43.188657 [ 3024 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:43.437584 [ 3114 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:43.549590 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:43.622428 [ 22703 ] {70bc6cb8-9b36-4e81-8140-b3c742f297a5} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50858) (comment: 00652_mergetree_mutations.sh) (in query: ALTER TABLE mutations DELETE WHERE d = '11'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000c6c0efd 5. /build/src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce66ca 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce661e 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 9. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008806bf2 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ec606 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 20. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String const&, bool&&) @ 0x00000000116ed138 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8933 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eae56 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f388 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:22:43.640641 [ 22703 ] {70bc6cb8-9b36-4e81-8140-b3c742f297a5} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000c6c0efd 5. /build/src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce66ca 6. /build/src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000010ce661e 7. /build/src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d9890 8. /build/src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000118d7415 9. /build/src/Functions/FunctionsComparison.h:0: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008806bf2 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000087ec606 11. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 12. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 13. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 17. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 18. /build/src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000012fb09b0 19. /build/src/Processors/QueryPlan/FilterStep.cpp:19: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x0000000013151883 20. /build/contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String const&, bool&&) @ 0x00000000116ed138 21. /build/src/Interpreters/MutationsInterpreter.cpp:1294: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000116e8933 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000116eae56 23. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f388 24. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 25. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 26. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 29. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 2025.06.25 16:22:44.048893 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:44.159293 [ 22703 ] {0e8ee418-9701-49db-93be-f9edcbea66a9} executeQuery: Code: 47. DB::Exception: Missing columns: 'a' while processing query: '_CAST(if(a = 0, _CAST(concat(s, ''), 'String'), s), 'String'), s', required columns: 'a' 's', maybe you meant: 'd' or 's'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50890) (comment: 00652_mergetree_mutations.sh) (in query: ALTER TABLE mutations UPDATE s = s || '' WHERE a = 0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000001187c12a 4. /build/src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011884155 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7669 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e48e7 7. /build/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) @ 0x00000000116df034 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:22:44.181192 [ 22703 ] {0e8ee418-9701-49db-93be-f9edcbea66a9} TCPHandler: Code: 47. DB::Exception: Missing columns: 'a' while processing query: '_CAST(if(a = 0, _CAST(concat(s, ''), 'String'), s), 'String'), s', required columns: 'a' 's', maybe you meant: 'd' or 's'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000001187c12a 4. /build/src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000011884155 5. /build/src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000116e7669 6. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e48e7 7. /build/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) @ 0x00000000116df034 8. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:22:44.190420 [ 3261 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:44.439375 [ 3179 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:44.532570 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:45.072674 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:45.179019 [ 3635 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_5} 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.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.182615 [ 3635 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.196855 [ 3170 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.446175 [ 3495 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.467075 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:45.564620 [ 3619 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_5} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.566287 [ 3619 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_5} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.824488 [ 3636 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000201_20000201_4_4_0_6} 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.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.826044 [ 3636 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000201_20000201_4_4_0_6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:45.854570 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:46.198572 [ 3272 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.258595 [ 3625 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} 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.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.268866 [ 3625 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.342833 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:46.424279 [ 3635 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.426662 [ 3627 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.426951 [ 3635 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.428683 [ 3627 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.467805 [ 3264 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.689680 [ 3636 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.739271 [ 3636 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_3_3_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.768250 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:46.768911 [ 3638 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:46.775001 [ 3638 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:47.120259 [ 3639 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:47.149427 [ 3639 ] {5b2f9727-c130-4163-8fa4-7c2133fdd430::20000101_20000101_2_2_0_7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60ee5 9. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 10. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 11. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:47.151465 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:47.201535 [ 3503 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:47.472182 [ 3171 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:47.784042 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:48.171530 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:48.203561 [ 3321 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:48.473918 [ 3188 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:48.511563 [ 22706 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:48.714519 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:49.157130 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:49.205572 [ 3166 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:49.475653 [ 3163 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:49.925871 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:50.107867 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:50.207566 [ 3276 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:50.479815 [ 3145 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:51.076384 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:51.085514 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:51.209467 [ 3490 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:51.481779 [ 3335 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:51.980268 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:52.041631 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:52.211556 [ 3510 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:52.561259 [ 3315 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:52.964861 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:53.003460 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:53.213567 [ 3256 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:53.563454 [ 3415 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:54.040270 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:54.068678 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:54.215715 [ 3364 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:54.567939 [ 3065 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:55.048089 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:55.083588 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:55.217736 [ 3060 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:55.575728 [ 3308 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:56.035070 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:56.063109 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:56.219580 [ 3140 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:56.578589 [ 3417 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:57.113374 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:57.116168 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:57.221464 [ 3420 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:57.580485 [ 3075 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:58.044325 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:58.173223 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:58.232059 [ 3036 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:58.585534 [ 3174 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:59.072943 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:59.208598 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:22:59.238712 [ 3010 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:22:59.590054 [ 3396 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:00.072267 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:00.237816 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:00.240646 [ 3455 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:00.591919 [ 3436 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:01.123238 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:01.254389 [ 3268 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:01.327247 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:01.596426 [ 3313 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:02.144116 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:02.256089 [ 3152 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:02.310994 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:02.600499 [ 3246 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:03.068575 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:03.260966 [ 3148 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:03.292646 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:03.602829 [ 3311 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:03.942219 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:04.228717 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:04.265810 [ 3116 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:04.604854 [ 3114 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:04.856250 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:05.270663 [ 3101 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:05.304567 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:05.606913 [ 3467 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:05.815723 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:06.273023 [ 3211 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:06.324658 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:06.611296 [ 3365 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:06.917819 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:07.317403 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:07.377424 [ 3447 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:07.613657 [ 3174 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:07.920504 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:08.133061 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:08.379322 [ 3266 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:08.615818 [ 3285 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:08.861455 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:09.047170 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:09.381599 [ 3348 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:09.617522 [ 3123 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:09.717060 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:09.979582 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:10.383416 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:10.440994 [ 22706 ] {cbe0b875-7f75-4088-9a29-ea0d1432d143} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49132) (comment: 00652_mergetree_mutations.sh) (in query: DROP DATABASE IF EXISTS test_qczs1ljp ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:23:10.445328 [ 22706 ] {cbe0b875-7f75-4088-9a29-ea0d1432d143} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:10.581639 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:10.619310 [ 3425 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:11.045730 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:11.385664 [ 3344 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:11.521948 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:11.626279 [ 3375 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:12.048509 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:12.387762 [ 3026 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:12.541863 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:12.630793 [ 3138 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:13.060898 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:13.389835 [ 3103 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:13.489686 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:13.632491 [ 3109 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:14.046849 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:14.380717 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:14.397939 [ 3498 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:14.634370 [ 3246 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:15.043174 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:15.360360 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:15.402064 [ 3032 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:15.636370 [ 3240 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:16.055018 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:16.348015 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:16.404130 [ 3226 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:16.638498 [ 3150 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:17.060120 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:17.241123 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:17.411903 [ 3252 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:17.643214 [ 3265 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:18.087972 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:18.154245 [ 3635 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c944daf9-de77-4918-ae2f-90aeb61f7cdd::202506_1_116_32}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:18.155510 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:18.416431 [ 3042 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:18.645328 [ 3311 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:19.100401 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:19.106160 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:19.421078 [ 3147 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:19.650067 [ 3092 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:20.061571 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:20.181522 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:20.423019 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:20.652276 [ 3377 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:20.977813 [ 22712 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:21.073677 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:21.428508 [ 3007 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:21.654023 [ 3101 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:21.877674 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:22.011613 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:22.430327 [ 3188 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:22.655635 [ 3284 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:22.765674 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:22.896878 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:23.434336 [ 3520 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:23.658938 [ 3091 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:23.750541 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:23.889616 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:24.436206 [ 3145 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:24.636469 [ 22700 ] {4cc8f565-bd7e-4132-ab1b-fd478c3d57a0} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36608) (comment: 00056_view.sql) (in query: DROP TABLE test.view;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:24.655138 [ 22700 ] {4cc8f565-bd7e-4132-ab1b-fd478c3d57a0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:24.664149 [ 3199 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:24.793768 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:24.871956 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:25.256915 [ 3332 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:25.438122 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:25.640558 [ 3998 ] {b5897207-a30d-42e1-a2cf-6121c283e50b} executeQuery: Code: 57. DB::Exception: Table test.basic already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58290) (comment: 00041_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits_null GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:23:25.660722 [ 3998 ] {b5897207-a30d-42e1-a2cf-6121c283e50b} TCPHandler: Code: 57. DB::Exception: Table test.basic already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:23:25.666133 [ 3090 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:25.835234 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:25.934813 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:26.439729 [ 3202 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:26.668093 [ 3352 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:26.982795 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:26.983822 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:27.441536 [ 3507 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:27.713864 [ 3312 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:27.942890 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:27.999162 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:28.443773 [ 3404 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:28.715834 [ 3333 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:28.850185 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:28.933936 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:29.448730 [ 3501 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:29.718015 [ 3289 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:29.877965 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:29.935274 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:30.450782 [ 3495 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:30.723467 [ 3231 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:30.945268 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:30.992157 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:31.452968 [ 3416 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:31.728137 [ 3361 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:31.921348 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:32.036526 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:32.454921 [ 3350 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:32.729866 [ 3236 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:32.761648 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:32.991624 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:33.456714 [ 3069 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:33.731833 [ 3297 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:33.747710 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:34.203370 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:34.464111 [ 3147 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:34.734087 [ 3113 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:34.840787 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:35.197932 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:35.466103 [ 3257 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:35.681336 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:35.736025 [ 3259 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:36.107422 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:36.468061 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:36.676551 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:36.738216 [ 3004 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:37.103790 [ 22703 ] {142e7a2c-6955-4c91-b300-8c382d74bf6e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53572) (comment: 00160_decode_xml_component.sql) (in query: SELECT sum(DISTINCT sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:23:37.113208 [ 22703 ] {142e7a2c-6955-4c91-b300-8c382d74bf6e} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:23:37.160301 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:37.470309 [ 3121 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:37.726886 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:37.740116 [ 3160 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:38.210806 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:38.472295 [ 3315 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:38.675773 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:38.744477 [ 3195 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:39.251339 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:39.474456 [ 3188 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:39.749079 [ 3067 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:39.793305 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:40.343869 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:40.479201 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:40.751109 [ 3312 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:40.774464 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:41.469795 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:41.481416 [ 3335 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:41.753023 [ 3492 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:41.773891 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:42.441918 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:42.485448 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:42.756859 [ 3084 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:42.784721 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:43.393873 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:43.487370 [ 3077 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:43.762079 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:43.777270 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:44.373237 [ 5056 ] {9c7bfd69-0fbf-478c-969b-c8abe2a3273c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53586) (comment: 00094_order_by_array_join_limit.sql) (in query: WITH arrayJoin(`ParsedParams.Key2`) AS pp SELECT ParsedParams.Key2 AS x FROM test.hits ORDER BY x ASC LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:23:44.381707 [ 5056 ] {9c7bfd69-0fbf-478c-969b-c8abe2a3273c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:23:44.469633 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:44.491722 [ 3110 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:44.763072 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:44.763804 [ 3253 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:45.406963 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:45.496007 [ 3427 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:45.641590 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:45.766124 [ 3142 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:46.410126 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:46.506163 [ 3405 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:46.621646 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:46.768393 [ 3476 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:47.470936 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:47.507835 [ 3372 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:47.659198 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:47.779095 [ 3104 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:47.784307 [ 3625 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bde1766a-25bc-4118-bf12-518f2f20b3dc::202506_1_135_27}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:48.512324 [ 3507 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:48.518997 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:48.689222 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:48.788566 [ 3459 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:49.514329 [ 3388 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:49.602312 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:49.780802 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:49.791593 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:50.518270 [ 3183 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:50.615177 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:50.650375 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:50.794090 [ 3337 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:51.494279 [ 22705 ] {17a4afde-a347-43fa-87b2-61538562f2f1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column ResolutionWidth): (while reading from part /var/lib/clickhouse/store/9f2/9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672/201403_1_10_1/ in table test.hits (9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672) located on disk default of type local, from mark 72 with max_rows_to_read = 78014): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47108) (comment: 00145_aggregate_functions_statistics.sql) (in query: SELECT round(covarSamp(ResolutionWidth, ResolutionHeight), 6) FROM test.hits;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000104ce6c8 12. /build/contrib/llvm-project/libcxx/include/optional:344: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8b7e 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128f6f6f 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000128f6a6f 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:142: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f71ab 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 21. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:23:51.497798 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:51.512683 [ 22705 ] {17a4afde-a347-43fa-87b2-61538562f2f1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=1): (while reading column ResolutionWidth): (while reading from part /var/lib/clickhouse/store/9f2/9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672/201403_1_10_1/ in table test.hits (9f2c0ed3-fcdc-4b6a-bc95-d50c4bf95672) located on disk default of type local, from mark 72 with max_rows_to_read = 78014): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d799a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000104d778f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000104d69b0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000104ce5e2 11. /build/contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000104ce6c8 12. /build/contrib/llvm-project/libcxx/include/optional:344: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8b7e 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128f6f6f 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x00000000128f6a6f 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:142: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f71ab 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 20. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 21. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 22. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:23:51.526973 [ 3418 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:51.538527 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:51.796250 [ 3260 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:52.474216 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:52.529267 [ 3404 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:52.638924 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:52.804889 [ 3130 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:53.492116 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:53.601396 [ 3375 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:53.655872 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:53.809950 [ 3122 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:54.408969 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:54.481956 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:54.602882 [ 3390 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:54.812033 [ 3261 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:54.983394 [ 23388 ] {acad0c2a-3c89-499a-af48-1d51680e555c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=7): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47310) (comment: 00154_avro.sql) (in query: INSERT INTO test.avro SELECT * FROM test.hits LIMIT 10000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d60348 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:23:55.111307 [ 23388 ] {acad0c2a-3c89-499a-af48-1d51680e555c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=7): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d60348 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d5eec7 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:23:55.270601 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:55.448672 [ 29864 ] {af6439a1-e154-47a0-86a7-170b947d1a37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=762). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43280) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: SELECT length(groupUniqArray(`__table1`.`v`)) AS `length(groupUniqArray(v))` FROM `test_ytwl1swb`.`group_uniq_arr_int` AS `__table1` GROUP BY `__table1`.`id` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:23:55.459705 [ 29864 ] {af6439a1-e154-47a0-86a7-170b947d1a37} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=762). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:23:55.521681 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:55.616465 [ 3399 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:55.651783 [ 26622 ] {031cb7ec-c85b-4d62-89fb-469b98796cec} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=762). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36948) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: SELECT length(groupUniqArray(v)) FROM remote('127.0.0.{2,3,4,5}', currentDatabase(), 'group_uniq_arr_int') GROUP BY id ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:23:55.672507 [ 23388 ] {992cd9b9-c1c0-41d2-9e18-796702560af0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55692). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55692) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: SELECT length(groupUniqArray(`__table1`.`v`)) AS `length(groupUniqArray(v))` FROM `test_ytwl1swb`.`group_uniq_arr_int` AS `__table1` GROUP BY `__table1`.`id` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:23:55.677246 [ 23388 ] {992cd9b9-c1c0-41d2-9e18-796702560af0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55692). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:55.684792 [ 23388 ] {992cd9b9-c1c0-41d2-9e18-796702560af0} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55692). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:23:55.690300 [ 23388 ] {992cd9b9-c1c0-41d2-9e18-796702560af0} TCPHandler: Client has gone away. 2025.06.25 16:23:55.694350 [ 6665 ] {72153d56-ecf7-40a7-9807-8a51cfaa21c9} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:33084). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33084) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: SELECT length(groupUniqArray(`__table1`.`v`)) AS `length(groupUniqArray(v))` FROM `test_ytwl1swb`.`group_uniq_arr_int` AS `__table1` GROUP BY `__table1`.`id` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:23:55.730115 [ 6665 ] {72153d56-ecf7-40a7-9807-8a51cfaa21c9} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:33084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:55.749572 [ 6665 ] {72153d56-ecf7-40a7-9807-8a51cfaa21c9} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:33084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789c3a 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x0000000012cc05ba 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb5646 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 7. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 10. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 2025.06.25 16:23:55.759556 [ 26622 ] {031cb7ec-c85b-4d62-89fb-469b98796cec} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=762). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:23:55.780807 [ 6665 ] {72153d56-ecf7-40a7-9807-8a51cfaa21c9} TCPHandler: Client has gone away. 2025.06.25 16:23:55.814113 [ 3235 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:55.859520 [ 2956 ] {62044fba-de2d-4d76-a8aa-01461e2c05db} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:50934). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50934) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: SELECT length(groupUniqArray(`__table1`.`v`)) AS `length(groupUniqArray(v))` FROM `test_ytwl1swb`.`group_uniq_arr_int` AS `__table1` GROUP BY `__table1`.`id` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x0000000012cbfc4f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf96a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:23:55.959477 [ 2956 ] {62044fba-de2d-4d76-a8aa-01461e2c05db} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:50934). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x0000000012ccbbcf 5. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x0000000012cc0362 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::runImpl() @ 0x0000000012cb57d5 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:55.961886 [ 2956 ] {62044fba-de2d-4d76-a8aa-01461e2c05db} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:50934). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x0000000012cbfc4f 5. /build/src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf96a 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:23:55.971779 [ 2956 ] {62044fba-de2d-4d76-a8aa-01461e2c05db} TCPHandler: Client has gone away. 2025.06.25 16:23:56.236111 [ 4370 ] {ce07a79f-d1fa-4dbd-8a62-071a3a38a027} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40234) (comment: 00171_grouping_aggregated_transform_bug.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID) SETTINGS max_block_size = 63169;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:23:56.256330 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:56.314647 [ 4370 ] {ce07a79f-d1fa-4dbd-8a62-071a3a38a027} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:23:56.517883 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:56.618928 [ 3396 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:56.819116 [ 3098 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:57.110803 [ 22712 ] {5f07b686-1b5c-4328-8587-c1a02bc0adeb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49778) (comment: 00376_shard_group_uniq_array_of_int_array.sql) (in query: DROP DATABASE IF EXISTS test_ytwl1swb ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:23:57.115338 [ 22712 ] {5f07b686-1b5c-4328-8587-c1a02bc0adeb} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:57.154665 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:57.530083 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:57.620727 [ 3425 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:57.821013 [ 3342 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:57.956894 [ 4370 ] {query_id_memory_bound_merging_141056593} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY CounterID, URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40326) (comment: 00177_memory_bound_merging.sh) (in query: SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY CounterID, URL, EventDate ORDER BY URL, EventDate LIMIT 5 OFFSET 10 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:23:58.005489 [ 4370 ] {query_id_memory_bound_merging_141056593} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY CounterID, URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:23:58.132885 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:58.355057 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:58.660285 [ 3351 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:58.666997 [ 8172 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:58.823021 [ 3041 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:59.135949 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:59.404014 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:23:59.662934 [ 3284 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:23:59.829592 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:00.173827 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:00.394655 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:00.667358 [ 3491 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:00.831507 [ 3353 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:01.021974 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:01.400125 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:01.669868 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:01.833632 [ 3012 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:02.163843 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:02.460804 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:02.671727 [ 3193 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:02.835699 [ 3519 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:03.201042 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:03.329463 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:03.676471 [ 3089 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:03.816490 [ 8172 ] {715b1930-cea0-4278-927b-c61b9e005c86} executeQuery: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40672) (comment: 01715_table_function_view_fix.sql) (in query: SELECT sumIf(dummy, dummy) FROM remote('127.0.0.{1,2}', numbers(2, 100), view(SELECT CAST(NULL, 'Nullable(UInt8)') AS dummy FROM system.one));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Parsers/ASTFunction.cpp:40: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000134f67cc 5. /build/src/Parsers/IAST.cpp:0: DB::IAST::getColumnName() const @ 0x0000000013572b6d 6. /build/contrib/llvm-project/libcxx/include/string:1624: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000111b7176 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000111b76a9 8. /build/src/Storages/StorageDistributed.cpp:214: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000012231b4a 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000001223053e 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000010268d20 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102666ef 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 13. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:24:03.837783 [ 3517 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:03.837993 [ 8172 ] {715b1930-cea0-4278-927b-c61b9e005c86} TCPHandler: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Parsers/ASTFunction.cpp:40: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000134f67cc 5. /build/src/Parsers/IAST.cpp:0: DB::IAST::getColumnName() const @ 0x0000000013572b6d 6. /build/contrib/llvm-project/libcxx/include/string:1624: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000111b7176 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x00000000111b76a9 8. /build/src/Storages/StorageDistributed.cpp:214: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000012231b4a 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x000000001223053e 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x0000000010268d20 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102666ef 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 13. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:24:04.226582 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:04.443163 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:04.682111 [ 3288 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:04.839672 [ 3154 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:05.186241 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:05.484368 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:05.688016 [ 3088 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:05.841585 [ 3301 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:06.204946 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:06.529250 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:06.693677 [ 3286 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:06.843332 [ 3142 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:07.010164 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:07.448134 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:07.695968 [ 3419 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:07.845719 [ 3476 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:07.929677 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:08.504177 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:08.707263 [ 3341 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:08.824770 [ 22705 ] {4ca5f8c1-7063-474b-8f87-af6c09192288} executeQuery: Code: 57. DB::Exception: Table test_0qhdtulw.multidimensional already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59756) (comment: 00521_multidimensional.sql) (in query: CREATE TABLE multidimensional (x UInt64, arr Array(Array(String)), t Tuple(String, Array(Nullable(String)), Tuple(UInt32, Date))) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:24:08.832908 [ 22705 ] {4ca5f8c1-7063-474b-8f87-af6c09192288} TCPHandler: Code: 57. DB::Exception: Table test_0qhdtulw.multidimensional already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:24:08.847793 [ 3466 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:08.904576 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:09.512886 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:09.711667 [ 3078 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:09.847462 [ 5056 ] {4e8fca5b-6b27-41d5-8e9b-bead1fa0b0c8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59970) (comment: 02771_semi_join_use_nulls.gen.sql) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:09.851056 [ 3031 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:09.852083 [ 5056 ] {4e8fca5b-6b27-41d5-8e9b-bead1fa0b0c8} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000010885af3 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000110e9b69 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000116a3bea 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:09.896494 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:10.628507 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:10.716115 [ 3275 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:10.853118 [ 3214 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:10.860477 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:11.049238 [ 4370 ] {988fa4a0-3bf0-4ec3-a6ca-d377e208c043} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40382) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_141056593' AND initial_query_id = 'query_id_memory_bound_merging_141056593' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:24:11.067588 [ 4370 ] {988fa4a0-3bf0-4ec3-a6ca-d377e208c043} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:24:11.589577 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:11.715635 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:11.718144 [ 3270 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:11.857006 [ 3362 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:12.135640 [ 22705 ] {query_id_memory_bound_merging_71716629} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, query_plan_aggregation_in_order = 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60040) (comment: 00177_memory_bound_merging.sh) (in query: SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate ORDER BY URL, EventDate LIMIT 5 OFFSET 10 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, query_plan_aggregation_in_order = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:24:12.174404 [ 22705 ] {query_id_memory_bound_merging_71716629} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate ORDER BY URL ASC, EventDate ASC LIMIT 10, 5 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, query_plan_aggregation_in_order = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:24:12.497866 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:12.560043 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:12.722964 [ 3186 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:12.858580 [ 3429 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:13.608351 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:13.638166 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:13.724654 [ 3067 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:13.863096 [ 3370 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:14.621498 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:14.651690 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:14.726699 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:14.865310 [ 3232 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:15.515795 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:15.606207 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:15.728557 [ 3352 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:15.867281 [ 3213 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:16.460583 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:16.603649 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:16.730616 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:16.869644 [ 3135 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:17.029734 [ 22705 ] {5c0c78e1-2829-466d-b226-9588683f6fc4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37282) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:17.053870 [ 22705 ] {5c0c78e1-2829-466d-b226-9588683f6fc4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:17.481773 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:17.594823 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:17.745503 [ 3482 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:17.871827 [ 3379 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:18.418885 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:18.649362 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:18.748567 [ 3101 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:18.883519 [ 3141 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:19.467865 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:19.657303 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:19.750380 [ 3004 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:19.889483 [ 3096 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:20.343139 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:20.753850 [ 3144 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:20.788348 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:20.891680 [ 3426 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:21.393618 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:21.763229 [ 3037 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:21.891316 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:21.893748 [ 3487 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:22.514739 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:22.569623 [ 22706 ] {5c7c0d61-7fe6-4300-96dc-e3ec4ecf2a13} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37552) (comment: 01273_arrow.sh) (in query: SELECT * FROM arrow_types6 ORDER BY int8), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:24:22.603499 [ 22706 ] {5c7c0d61-7fe6-4300-96dc-e3ec4ecf2a13} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:24:22.765555 [ 3186 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:22.786033 [ 22706 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:22.824693 [ 6985 ] {d1577623-7755-4871-b853-d64db304846a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54846) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_7xi1res5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:22.827829 [ 6985 ] {d1577623-7755-4871-b853-d64db304846a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:22.899313 [ 3228 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:22.969106 [ 22706 ] {bb141425-2659-4c8b-b3ef-c0161759e938} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54860) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_7xi1res5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:22.971938 [ 22706 ] {bb141425-2659-4c8b-b3ef-c0161759e938} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.062534 [ 2956 ] {ced1b707-5c4f-4950-bb50-714ad291be63} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54866) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_7xi1res5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:23.066820 [ 2956 ] {ced1b707-5c4f-4950-bb50-714ad291be63} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.153401 [ 22706 ] {3e9c80c6-5ca2-4ca7-b49f-72688d4f70f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54870) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_7xi1res5 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:24:23.162866 [ 22706 ] {3e9c80c6-5ca2-4ca7-b49f-72688d4f70f4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.269199 [ 2956 ] {ceb316b8-6c8b-4e8a-871d-3e2308ae03d3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:578472ee-3668-42db-a291-c2f4ff43e1ae'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54872) (comment: 01252_weird_time_zone.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mmck454u ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:23.276977 [ 2956 ] {ceb316b8-6c8b-4e8a-871d-3e2308ae03d3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:578472ee-3668-42db-a291-c2f4ff43e1ae'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.500132 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:23.517609 [ 22706 ] {cd5082ce-d774-44e1-a1ee-f6fac922a999} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5337e971-bab3-442c-8034-b77439fdc6f1'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54878) (comment: 00873_t64_codec_date.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x80whd0q ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:23.537076 [ 22706 ] {cd5082ce-d774-44e1-a1ee-f6fac922a999} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5337e971-bab3-442c-8034-b77439fdc6f1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.659935 [ 6398 ] {81852f23-20ec-4df3-a327-819aa9d31b9d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:ae29ead4-7b6d-486e-b708-5c750f4dc01b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54888) (comment: 02122_parallel_formatting_JSONStringsEachRow.sh) (in query: CREATE DATABASE IF NOT EXISTS test_xwi4onpb ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:23.679406 [ 6398 ] {81852f23-20ec-4df3-a327-819aa9d31b9d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:ae29ead4-7b6d-486e-b708-5c750f4dc01b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.771905 [ 3081 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.815720 [ 22706 ] {19b1d85c-88c1-443e-84ad-48e8560f7c74} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:9fde04c2-0f4d-44ff-b4d7-57c57d884584'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54898) (comment: 00965_send_logs_level_concurrent_queries.sh) (in query: CREATE DATABASE IF NOT EXISTS test_leay6dci ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:23.819277 [ 22706 ] {19b1d85c-88c1-443e-84ad-48e8560f7c74} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:9fde04c2-0f4d-44ff-b4d7-57c57d884584'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.901564 [ 3161 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:23.945071 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:24.004069 [ 22712 ] {bc888c14-21f8-4762-92dd-7d69a5d7d8f0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:e243dab5-2d24-4c23-8aed-f1959fdf2ea0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54910) (comment: 03207_json_read_subcolumns_1_compact_merge_tree.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nv70xwgi ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.075586 [ 22712 ] {bc888c14-21f8-4762-92dd-7d69a5d7d8f0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:e243dab5-2d24-4c23-8aed-f1959fdf2ea0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.257044 [ 22706 ] {908af316-48b4-4b88-a1ea-1ce085891aca} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:68f00ffc-fbbd-460d-b049-dba59deaed65'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54922) (comment: 03210_variant_with_aggregate_function_type.sql) (in query: CREATE DATABASE IF NOT EXISTS test_epdqdraz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.258931 [ 22706 ] {908af316-48b4-4b88-a1ea-1ce085891aca} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:68f00ffc-fbbd-460d-b049-dba59deaed65'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.327162 [ 6398 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:24.369892 [ 22706 ] {cc3c579d-f620-41e7-a691-edf2d9306518} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:44f409f0-d315-43fc-9c11-c2d214252cec'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40366) (comment: 03013_hop_infinite_loop.sql) (in query: CREATE DATABASE IF NOT EXISTS test_w1ck8o9y ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.383325 [ 22706 ] {cc3c579d-f620-41e7-a691-edf2d9306518} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:44f409f0-d315-43fc-9c11-c2d214252cec'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.471947 [ 6398 ] {1d99a33b-54ba-487e-9cf3-79b5521bf2c0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:3ae479c2-1c5e-4d9e-aa96-541296ac64e8'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40368) (comment: 00838_system_tables_drop_table_race.sh) (in query: CREATE DATABASE IF NOT EXISTS test_flj5cu9w ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.483188 [ 6398 ] {1d99a33b-54ba-487e-9cf3-79b5521bf2c0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:3ae479c2-1c5e-4d9e-aa96-541296ac64e8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.601730 [ 22706 ] {054ed73d-0d8b-45bb-888c-5ad3bd9c13fd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5c6edd3d-ebe2-4bc4-bcf1-e8095abf22b5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40378) (comment: 01556_explain_select_with_union_query.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vb6t1x58 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.618338 [ 22706 ] {054ed73d-0d8b-45bb-888c-5ad3bd9c13fd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5c6edd3d-ebe2-4bc4-bcf1-e8095abf22b5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.727459 [ 2956 ] {b0b648d0-c2b2-4eba-9e3d-b94712fc7657} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:1202c0cb-c20e-4fe7-b96e-016fd8912fc5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40386) (comment: 00236_replicated_drop_on_non_leader_zookeeper_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q57a7c5i ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.733265 [ 2956 ] {b0b648d0-c2b2-4eba-9e3d-b94712fc7657} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:1202c0cb-c20e-4fe7-b96e-016fd8912fc5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.779086 [ 3262 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.866454 [ 22706 ] {9a598142-6a0a-47f8-8afe-1524a27d9ae7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:7cb3b485-774c-4b83-9f96-384a0fc9a9d9'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40402) (comment: 00754_first_significant_subdomain_more.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nbfy2hqk ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:24.886986 [ 22706 ] {9a598142-6a0a-47f8-8afe-1524a27d9ae7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:7cb3b485-774c-4b83-9f96-384a0fc9a9d9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.903222 [ 3134 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:24.938296 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:25.091376 [ 26622 ] {db691f9b-18c6-46f9-825f-dbfc194cda39} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:8d6c5791-8e6c-4d67-95fc-763f56239f60'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40404) (comment: 02270_stdin_with_query_or_infile_data.sh) (in query: CREATE DATABASE IF NOT EXISTS test_i0302hx6 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.094871 [ 26622 ] {db691f9b-18c6-46f9-825f-dbfc194cda39} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:8d6c5791-8e6c-4d67-95fc-763f56239f60'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.182085 [ 2956 ] {bbc222a5-5151-429b-8a52-fb71623acb48} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5e54e8ba-2ae8-4b9c-b0ab-625792566bf6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40420) (comment: 00105_shard_collations.sql) (in query: CREATE DATABASE IF NOT EXISTS test_81wz8nq9 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.198963 [ 2956 ] {bbc222a5-5151-429b-8a52-fb71623acb48} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:5e54e8ba-2ae8-4b9c-b0ab-625792566bf6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.291450 [ 26622 ] {11248857-740a-4ea5-ab72-59bba7cea35c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:90699a1e-2740-4bb7-818b-1b9d6cb3c1ea'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40436) (comment: 01882_check_max_parts_to_merge_at_once.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6vh0ct6k ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.322238 [ 26622 ] {11248857-740a-4ea5-ab72-59bba7cea35c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:90699a1e-2740-4bb7-818b-1b9d6cb3c1ea'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.366343 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:25.400227 [ 22672 ] {1f6a151e-7e14-471c-a036-42031847d16a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:8df4ab27-12a2-4465-911d-8304ea35a8e6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40438) (comment: 01840_tupleElement_formatting_fuzzer.sql) (in query: CREATE DATABASE IF NOT EXISTS test_eh73vset ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.403806 [ 22672 ] {1f6a151e-7e14-471c-a036-42031847d16a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:8df4ab27-12a2-4465-911d-8304ea35a8e6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.473019 [ 22706 ] {082fcfbd-4a3a-4428-9a23-394e00239e64} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:e7045c2a-97a1-4757-a153-c8e7cadd0c69'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40450) (comment: 02226_parallel_reading_from_replicas_benchmark.sh) (in query: CREATE DATABASE IF NOT EXISTS test_4hoj8zf8 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.484499 [ 22706 ] {082fcfbd-4a3a-4428-9a23-394e00239e64} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:e7045c2a-97a1-4757-a153-c8e7cadd0c69'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.578201 [ 2956 ] {1e372895-78aa-470f-8b9b-48409deb3603} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:ed2a9ec1-dfae-45c6-a1ac-41a12db18b42'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40454) (comment: 00431_if_nulls.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xzo3shen ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.586489 [ 2956 ] {1e372895-78aa-470f-8b9b-48409deb3603} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:ed2a9ec1-dfae-45c6-a1ac-41a12db18b42'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.783811 [ 3021 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.793053 [ 22706 ] {5fee0fbf-8e1e-4ffb-87be-241a24a07392} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:932b627b-dd11-4a1b-aead-830df26f96db'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40468) (comment: 00568_empty_function_with_fixed_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_c8fuxm42 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:25.796045 [ 22706 ] {5fee0fbf-8e1e-4ffb-87be-241a24a07392} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '60383288ac7c:9000:7962b52a-1deb-4a27-87dd-7c0e85d435a2', current host ID: '60383288ac7c:9000:932b627b-dd11-4a1b-aead-830df26f96db'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x0000000010dfcb99 4. /build/src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000010ddca90 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000010de0314 6. /build/src/Databases/TablesLoader.cpp:58: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a7c1 7. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:25.883467 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:25.906104 [ 3050 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:26.290182 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:26.785936 [ 3250 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:26.809871 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:26.910422 [ 3497 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:27.115887 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:27.430822 [ 26622 ] {92ab664f-be1f-4cfc-8d9a-e0709b12fd22} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, parallel_replicas_local_plan = 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54722) (comment: 00177_memory_bound_merging.sh) (in query: SELECT replaceRegexpOne(explain, '^ *(\w+).*', '\1') FROM ( EXPLAIN PIPELINE SELECT URL, EventDate, max(URL) FROM test.hits WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, parallel_replicas_local_plan=1 ) WHERE explain LIKE '%Aggr%Transform%' OR explain LIKE '%InOrder%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157a003 14. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 15. /build/src/Interpreters/InterpreterExplainQuery.h:11: DB::(anonymous namespace)::TableFunctionExplain::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a5301 16. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 17. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 22. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 29. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 2025.06.25 16:24:27.455269 [ 26622 ] {92ab664f-be1f-4cfc-8d9a-e0709b12fd22} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, parallel_replicas_local_plan = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001157a003 14. /build/src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x0000000011577c47 15. /build/src/Interpreters/InterpreterExplainQuery.h:11: DB::(anonymous namespace)::TableFunctionExplain::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000102a5301 16. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000104c1468 17. /build/src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000110e7a92 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001103d824 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110604e1 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 22. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 29. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 30. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 2025.06.25 16:24:27.763408 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:27.787865 [ 3309 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:27.914691 [ 3056 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:27.951784 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:28.661408 [ 22672 ] {c72f21c9-4f6e-4883-9b79-5e83e57a956b} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54780) (comment: 00044_any_left_join_string.sql) (in query: SELECT domain, hits, visits FROM ( SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain ) ANY LEFT JOIN ( SELECT domain(StartURL) AS domain, sum(Sign) AS visits FROM test.visits GROUP BY domain ) USING domain ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:24:28.677372 [ 22672 ] {c72f21c9-4f6e-4883-9b79-5e83e57a956b} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103908f 12. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060464 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 18. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 21. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 22. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:24:28.789947 [ 3084 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:28.802023 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:28.944764 [ 3119 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:29.481640 [ 2956 ] {4ccf7b6a-2e8e-4846-871e-ed20108e00c3} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID ASC. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54798) (comment: 00146_aggregate_function_uniq.sql) (in query: SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID ASC;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:24:29.488846 [ 2956 ] {4ccf7b6a-2e8e-4846-871e-ed20108e00c3} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT RegionID, uniqHLL12(WatchID) AS X FROM remote('127.0.0.{1,2}', test, hits) GROUP BY RegionID HAVING X > 100000 ORDER BY RegionID ASC. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 7. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 10. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 16. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 17. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 19. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 22. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 25. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 26. ? @ 0x00007f597a7a2ac3 27. ? @ 0x00007f597a834850 2025.06.25 16:24:29.794535 [ 3028 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:29.837195 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:29.947646 [ 3429 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:30.775225 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:30.796618 [ 3245 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:30.950271 [ 3076 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:31.800108 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:31.876538 [ 3476 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:31.964731 [ 3389 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:32.881322 [ 3508 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:32.916792 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:32.966887 [ 3215 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:33.865832 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:33.883230 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:33.969168 [ 3167 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.302017 [ 26622 ] {e42da551-f0cd-4d76-b503-d6f94db81ffe} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33506) (comment: 03169_cache_complex_dict_short_circuit_bug.sql) (in query: DROP DATABASE IF EXISTS test_roebv2du ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:34.305608 [ 26622 ] {e42da551-f0cd-4d76-b503-d6f94db81ffe} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.441010 [ 22672 ] {f6603d6e-0814-46ab-b829-6e7ba19c2f96} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33516) (comment: 03169_cache_complex_dict_short_circuit_bug.sql) (in query: DROP DATABASE IF EXISTS test_roebv2du ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:34.457190 [ 22672 ] {f6603d6e-0814-46ab-b829-6e7ba19c2f96} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.624417 [ 26622 ] {a270d77f-5251-4249-87ae-1cdbf00455be} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33526) (comment: 03169_cache_complex_dict_short_circuit_bug.sql) (in query: DROP DATABASE IF EXISTS test_roebv2du ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:34.637606 [ 26622 ] {a270d77f-5251-4249-87ae-1cdbf00455be} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.814743 [ 2956 ] {9f549934-f2ff-4265-ad41-a3a0c63a622c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33542) (comment: 03169_cache_complex_dict_short_circuit_bug.sql) (in query: DROP DATABASE IF EXISTS test_roebv2du ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:34.817582 [ 2956 ] {9f549934-f2ff-4265-ad41-a3a0c63a622c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.888129 [ 3058 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:34.948035 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:34.972010 [ 3459 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:35.890527 [ 3304 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:35.959184 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:35.974058 [ 3354 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:36.076494 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d7566a57-dd76-4fb1-a364-95d36c239568::202506_1_118_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:36.783774 [ 8172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:36.897538 [ 3337 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:36.975896 [ 3102 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:37.751858 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:37.899554 [ 3203 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:37.977901 [ 3323 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:38.473399 [ 5780 ] {4fed4306-b081-4610-9a8c-279bbb1af903} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:38.655248 [ 8172 ] {4fed4306-b081-4610-9a8c-279bbb1af903} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=7): (in file/uri /var/lib/clickhouse/user_files/test_9/data.JSONStringsEachRow.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46760) (comment: 02125_lz4_compression_bug_JSONStringsEachRow.sh) (in query: SELECT max(x) FROM file), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:24:38.691575 [ 8172 ] {4fed4306-b081-4610-9a8c-279bbb1af903} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=7): (in file/uri /var/lib/clickhouse/user_files/test_9/data.JSONStringsEachRow.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb41ba 8. /build/src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:53: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x0000000012eb2b96 9. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000012eb5fd9 10. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:24:38.719851 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:38.901895 [ 3272 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:38.980086 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:39.768384 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:39.904305 [ 3115 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:39.986303 [ 3132 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:40.689670 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:40.916287 [ 3330 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:40.988350 [ 3447 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:41.723922 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:41.927483 [ 3183 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:42.010277 [ 3388 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:42.620271 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:42.894811 [ 22700 ] {f974dfa3-a0da-4f54-b410-6037e35f2340} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=757). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46916) (comment: 03199_json_extract_dynamic.sql) (in query: select JSONExtract(materialize('{"d" : -42}'), 'd', 'Dynamic') as d, dynamicType(d);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:42.902332 [ 22700 ] {f974dfa3-a0da-4f54-b410-6037e35f2340} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=757). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:42.929413 [ 3040 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:43.012651 [ 3091 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:43.588907 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:43.931175 [ 3236 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:44.014888 [ 3045 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:44.535909 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:44.939861 [ 3083 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:45.027624 [ 3180 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:45.578174 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:45.945541 [ 3470 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.038062 [ 3449 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.301445 [ 22700 ] {e253c3c0-4daa-4272-a11a-818cb0420f19} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39882) (comment: 01890_materialized_distributed_join.sh) (in query: create materialized view test_0cqotogy.test_distributed engine Distributed('test_cluster_two_shards', test_0cqotogy, 'test_shard', k) as select k, v from test_source;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012231e15 9. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000012230abf 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x000000001224c0e7 11. /build/src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000012246a40 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000122eb9cd 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000122f3987 18. /build/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&) @ 0x00000000122f2beb 19. /build/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 @ 0x00000000122537c7 20. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 23. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:24:46.321033 [ 22700 ] {e253c3c0-4daa-4272-a11a-818cb0420f19} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012231e15 9. /build/src/Storages/StorageDistributed.cpp:0: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000012230abf 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x000000001224c0e7 11. /build/src/Storages/StorageDistributed.cpp:0: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000012246a40 12. /build/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 @ 0x00000000122537c7 13. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 16. /build/src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x00000000122eb9cd 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&) @ 0x00000000122f3987 18. /build/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&) @ 0x00000000122f2beb 19. /build/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 @ 0x00000000122537c7 20. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 23. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 24. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 27. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 30. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 31. ? @ 0x00007f597a7a2ac3 2025.06.25 16:24:46.584313 [ 8172 ] {c0ea2a77-23ce-4dd3-a3e4-07455b2d24ce} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41022) (comment: 01890_materialized_distributed_join.sh) (in query: DROP DATABASE IF EXISTS test_0cqotogy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:46.587320 [ 8172 ] {c0ea2a77-23ce-4dd3-a3e4-07455b2d24ce} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.620807 [ 22672 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:46.787222 [ 22700 ] {63679ac5-795c-4ab1-9d3a-821f31639126} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41028) (comment: 01890_materialized_distributed_join.sh) (in query: DROP DATABASE IF EXISTS test_0cqotogy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:46.790307 [ 22700 ] {63679ac5-795c-4ab1-9d3a-821f31639126} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.875017 [ 22703 ] {fde66b69-399f-4265-879a-7cb728cdfbb0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41040) (comment: 01890_materialized_distributed_join.sh) (in query: DROP DATABASE IF EXISTS test_0cqotogy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:46.881264 [ 22703 ] {fde66b69-399f-4265-879a-7cb728cdfbb0} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.950272 [ 3239 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.956159 [ 22700 ] {17cbdc1b-2b47-4e64-a585-4781f1800548} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41054) (comment: 01890_materialized_distributed_join.sh) (in query: DROP DATABASE IF EXISTS test_0cqotogy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:46.958616 [ 22700 ] {17cbdc1b-2b47-4e64-a585-4781f1800548} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:46.998226 [ 5056 ] {2c103e6c-4760-4512-9657-393f47ba7a90} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39950) (comment: 01387_clear_column_default_depends.sql) (in query: SELECT * FROM test ORDER BY x, y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:24:47.001840 [ 5056 ] {2c103e6c-4760-4512-9657-393f47ba7a90} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:24:47.045689 [ 3356 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:47.065827 [ 22703 ] {2c786bf6-3728-4581-914b-4881e12e0805} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41068) (comment: 01890_materialized_distributed_join.sh) (in query: DROP DATABASE IF EXISTS test_0cqotogy ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:24:47.070556 [ 22703 ] {2c786bf6-3728-4581-914b-4881e12e0805} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:47.569226 [ 5056 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:47.952186 [ 3446 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:48.047667 [ 3382 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:48.558645 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:48.773675 [ 22700 ] {ce684ef3-b732-452f-960d-bde41967fc09} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40018) (comment: 02941_variant_type_4.sh) (in query: create table test (id UInt64, v Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:24:48.801778 [ 22700 ] {ce684ef3-b732-452f-960d-bde41967fc09} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:24:48.954072 [ 3300 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:49.088247 [ 3305 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:49.493934 [ 22700 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:49.747665 [ 22703 ] {1c192cf0-6e53-4194-aab9-fa77db8f7018} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt64) of argument of function toUInt8: while converting source column res to destination column y. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40048) (comment: 02941_variant_type_4.sh) (in query: insert into test with 'Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))' as type select number, multiIf(number % 6 == 0, CAST(NULL, type), number % 6 == 1, CAST(('str_' || toString(number))::Variant(String), type), number % 6 == 2, CAST(number, type), number % 6 == 3, CAST(('lc_str_' || toString(number))::LowCardinality(String), type), number % 6 == 4, CAST(tuple(number, number + 1)::Tuple(a UInt32, b UInt32), type), CAST(range(number % 20 + 1)::Array(UInt64), type)) as res from numbers(1200000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000711ae3b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 12. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 13. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 18. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 19. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::ExpressionTransform(DB::Block const&, std::shared_ptr) @ 0x0000000012fad8d3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000115fca8e 21. /build/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 @ 0x0000000010bdafce 22. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000115f8a0f 25. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 26. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:24:49.770266 [ 22703 ] {1c192cf0-6e53-4194-aab9-fa77db8f7018} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt64) of argument of function toUInt8: while converting source column res to destination column y. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000711ae3b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 12. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 13. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000010fcbd01 18. /build/src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000010fcad14 19. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::ExpressionTransform(DB::Block const&, std::shared_ptr) @ 0x0000000012fad8d3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000115fca8e 21. /build/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 @ 0x0000000010bdafce 22. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000010bdadcd 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010bdb469 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000115f8a0f 25. /build/src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x00000000115fbc0c 26. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 27. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 30. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 2025.06.25 16:24:49.958248 [ 3502 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:50.090450 [ 3009 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:50.186778 [ 22700 ] {5e999cec-d46a-4b26-8790-5ea964efa000} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40076) (comment: 02941_variant_type_4.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:24:50.197449 [ 22700 ] {5e999cec-d46a-4b26-8790-5ea964efa000} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:24:50.468186 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:50.960276 [ 3104 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:51.141605 [ 3469 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:51.314986 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:51.962560 [ 3357 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:52.143846 [ 3191 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:52.332586 [ 22703 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:52.970332 [ 3319 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:53.149405 [ 3458 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:53.353382 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:53.972519 [ 3509 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:54.151693 [ 3464 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:54.336577 [ 5174 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:54.978847 [ 3515 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:55.155463 [ 3219 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:55.175697 [ 45152 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:55.991027 [ 3052 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:56.156956 [ 4370 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:56.157143 [ 3293 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:56.759304 [ 45158 ] {d936008f-ba10-4b84-b5f0-205a2a3b26f1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=761). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48200) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:56.784114 [ 45158 ] {d936008f-ba10-4b84-b5f0-205a2a3b26f1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=761). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:24:56.994164 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:57.129521 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:57.159373 [ 3406 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:57.996200 [ 3082 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:58.011264 [ 45211 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:58.161597 [ 3203 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:59.000863 [ 3493 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:59.006190 [ 45211 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:24:59.163692 [ 3314 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:24:59.984193 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:00.004609 [ 3013 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:00.175318 [ 3329 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:01.036201 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:01.113534 [ 45211 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:01.177225 [ 3181 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.038182 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:02.040630 [ 3435 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.181299 [ 3170 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.271359 [ 22672 ] {38b1e06c-2441-4347-a4d0-bb7ccb6d00a6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37896) (comment: 02100_low_cardinality_nullable_null_default.sh) (in query: DROP DATABASE IF EXISTS test_mcioqyc8 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:02.273184 [ 22672 ] {38b1e06c-2441-4347-a4d0-bb7ccb6d00a6} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.320180 [ 45211 ] {ce7c85ec-ee83-4350-bec4-9d1e2d31aab7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37902) (comment: 02100_low_cardinality_nullable_null_default.sh) (in query: DROP DATABASE IF EXISTS test_mcioqyc8 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:02.322538 [ 45211 ] {ce7c85ec-ee83-4350-bec4-9d1e2d31aab7} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.385507 [ 45257 ] {d3966fb1-ee90-4298-a86c-9a7467a4d79a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37916) (comment: 02100_low_cardinality_nullable_null_default.sh) (in query: DROP DATABASE IF EXISTS test_mcioqyc8 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:02.387168 [ 45257 ] {d3966fb1-ee90-4298-a86c-9a7467a4d79a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:02.875652 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:03.042544 [ 3503 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:03.183378 [ 3057 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:03.655670 [ 6985 ] {5a7ba45a-c605-4c80-8c6f-eb128a4142ef} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00619_union_highlite.sql) (in query: DROP TABLE union;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:03.663654 [ 6985 ] {5a7ba45a-c605-4c80-8c6f-eb128a4142ef} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:03.740490 [ 45249 ] {080361d6-686f-4d43-aa6d-c761bf9a0d79} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37942) (comment: 00619_union_highlite.sql) (in query: DROP DATABASE IF EXISTS test_axlnhkjn ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:25:03.745627 [ 45249 ] {080361d6-686f-4d43-aa6d-c761bf9a0d79} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:03.796287 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:04.046924 [ 3379 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:04.185366 [ 3226 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:04.828061 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:05.079447 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:05.188097 [ 3093 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:05.928727 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:06.083913 [ 3351 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:06.190015 [ 3114 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:06.881268 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:07.086355 [ 3316 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:07.192025 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:07.911749 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:07.937688 [ 45257 ] {f6519d7b-01a6-4fc5-8df4-9a003d85534f} 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.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: -- Number of arguments should equal 1 SELECT byteSwap();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:25:07.940395 [ 45257 ] {f6519d7b-01a6-4fc5-8df4-9a003d85534f} 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), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:25:07.965653 [ 45257 ] {65dc82d0-a6e1-4534-b69b-99238c5f95ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(128, 129);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:25:07.983358 [ 45257 ] {65dc82d0-a6e1-4534-b69b-99238c5f95ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x0000000007b6b76b 4. /build/src/Functions/IFunction.cpp:0: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000007b69a2d 5. /build/contrib/llvm-project/libcxx/include/vector:553: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b69dd5 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:25:08.076351 [ 45257 ] {7ec68be9-bca3-4f13-91cc-c3ad71df1142} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: -- Input should be integral SELECT byteSwap('abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.084194 [ 45257 ] {7ec68be9-bca3-4f13-91cc-c3ad71df1142} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.104693 [ 3009 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:08.142135 [ 45257 ] {58334568-cc8f-4d33-a840-6623f650f91f} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFixedString('abc', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.144172 [ 45257 ] {58334568-cc8f-4d33-a840-6623f650f91f} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.194314 [ 3170 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:08.225988 [ 45257 ] {92006502-5d52-4f4d-8011-914eb1c4a1c1} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDate('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.236324 [ 45257 ] {92006502-5d52-4f4d-8011-914eb1c4a1c1} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.297992 [ 45257 ] {d6cefe02-6cde-498a-80a1-8bff254f4897} executeQuery: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDate32('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.303001 [ 45257 ] {d6cefe02-6cde-498a-80a1-8bff254f4897} TCPHandler: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.354412 [ 45257 ] {66d296ce-7216-4d7c-b313-715310c1a8c8} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDateTime32(1546300800));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.357713 [ 45257 ] {66d296ce-7216-4d7c-b313-715310c1a8c8} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.487853 [ 45257 ] {811fc00c-b727-4dd9-a0c6-bfa6499df389} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDateTime64(1546300800, 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.490413 [ 45257 ] {811fc00c-b727-4dd9-a0c6-bfa6499df389} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.605975 [ 45257 ] {926a0c88-4dea-42a1-ad79-3ef9bae2fcc1} executeQuery: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(generateUUIDv4());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.618200 [ 45257 ] {926a0c88-4dea-42a1-ad79-3ef9bae2fcc1} TCPHandler: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.755930 [ 45257 ] {52f34026-b8f8-4521-a7b1-7e35aee4f615} executeQuery: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.760571 [ 45257 ] {52f34026-b8f8-4521-a7b1-7e35aee4f615} TCPHandler: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionUnaryArithmetic.h:0: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000084041e2 5. /build/contrib/llvm-project/libcxx/include/vector:438: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000700e8de 6. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 7. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 8. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 10. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 13. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 16. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 19. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 20. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 22. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 25. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 28. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:25:08.817412 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:08.875959 [ 45257 ] {8b6cbb76-a472-4d52-be0d-890917c44c9d} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFloat32(123.456));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/byteSwap.cpp:0: DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x0000000008407c66 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x0000000008407b94 6. /build/src/Functions/FunctionUnaryArithmetic.h:466: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000008404444 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008403720 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:25:08.881484 [ 45257 ] {8b6cbb76-a472-4d52-be0d-890917c44c9d} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/byteSwap.cpp:0: DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x0000000008407c66 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x0000000008407b94 6. /build/src/Functions/FunctionUnaryArithmetic.h:466: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x0000000008404444 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008403720 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:25:08.974237 [ 45257 ] {c70b0a88-0123-417c-b110-bde142c4d4a1} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40054) (comment: 02887_byteswap.sql) (in query: SELECT byteSwap(toFloat64(123.456));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/byteSwap.cpp:0: DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x0000000008407e66 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x0000000008407d94 6. /build/src/Functions/FunctionUnaryArithmetic.h:466: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x00000000084045a4 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000840375e 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:25:08.977311 [ 45257 ] {c70b0a88-0123-417c-b110-bde142c4d4a1} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/byteSwap.cpp:0: DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x0000000008407e66 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x0000000008407d94 6. /build/src/Functions/FunctionUnaryArithmetic.h:466: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x00000000084045a4 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000840375e 8. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 9. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 10. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 12. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 19. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 25. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 26. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 28. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 29. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 31. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 2025.06.25 16:25:09.106930 [ 3516 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:09.196012 [ 3483 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:09.838432 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:10.113208 [ 3079 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:10.197970 [ 3030 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:10.822456 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:11.115219 [ 3456 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:11.200206 [ 3272 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:11.872704 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:12.117135 [ 3218 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:12.202153 [ 3276 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:12.795878 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:13.120002 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:13.204140 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:13.882008 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:13.941564 [ 45257 ] {2c64288f-8550-4295-96ac-1d35c88764d7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=761). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40280) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:13.949213 [ 45257 ] {2c64288f-8550-4295-96ac-1d35c88764d7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=761). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:13.968432 [ 22705 ] {921ee250-767d-49e8-8c0d-c6cb6a42b182} executeQuery: Code: 57. DB::Exception: Table test_cts9x3jn.ttl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40236) (comment: 01070_modify_ttl.sql) (in query: CREATE TABLE ttl (`i` Int, `s` String) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 9668, 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 = 0, compact_parts_max_bytes_to_buffer = 514355015, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21380430, merge_max_block_size = 10127, old_parts_lifetime = 211., 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 = 976936178, index_granularity_bytes = 10867751, concurrent_part_removal_threshold = 52, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 8102, primary_key_compress_block_size = 82282), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:13.977659 [ 22705 ] {921ee250-767d-49e8-8c0d-c6cb6a42b182} TCPHandler: Code: 57. DB::Exception: Table test_cts9x3jn.ttl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:14.124388 [ 3200 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:14.206523 [ 3510 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:14.376443 [ 3621 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_137_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:14.797526 [ 6985 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:15.127979 [ 3177 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:15.208391 [ 3256 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:15.648340 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:16.129799 [ 3293 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:16.151318 [ 5777 ] {ee3b321e-85c0-4e89-8fce-bbefb42c8306} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:16.156315 [ 5777 ] {ee3b321e-85c0-4e89-8fce-bbefb42c8306} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:16.210137 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:16.210313 [ 3364 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:16.487130 [ 45257 ] {458776e3-8499-4e4a-a5b2-5ea12899684e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59062) (comment: 03206_replication_lag_metric.sql) (in query: DROP DATABASE rdb1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:16.505557 [ 45257 ] {458776e3-8499-4e4a-a5b2-5ea12899684e} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:16.710750 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:17.132030 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:17.213324 [ 3062 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:17.431170 [ 6665 ] {c4eaaaea-9e87-4fc4-b9be-894bccd8b615} executeQuery: Code: 82. DB::Exception: Database rdb1 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59126) (comment: 03206_replication_lag_metric.sql) (in query: CREATE DATABASE rdb1 ENGINE = Replicated('/test/test_replication_lag_metric', 'shard1', 'replica1');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:25:17.457273 [ 6665 ] {c4eaaaea-9e87-4fc4-b9be-894bccd8b615} TCPHandler: Code: 82. DB::Exception: Database rdb1 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:25:17.641651 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:18.136285 [ 3178 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:18.215363 [ 3455 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:18.569181 [ 45257 ] {7cac3e49-5574-4782-adba-10bec88a9769} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59160) (comment: 01032_cityHash64_for_decimal.sql) (in query: SELECT cityHash64(toDecimal64(64, 5));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:18.592382 [ 45257 ] {7cac3e49-5574-4782-adba-10bec88a9769} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:18.632309 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:18.797618 [ 6665 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:19.138369 [ 3059 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:19.217497 [ 3479 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:19.562984 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:20.140476 [ 3048 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:20.221933 [ 3499 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:20.537994 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:21.113436 [ 3203 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:21.144913 [ 3431 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:21.226496 [ 3326 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:21.607836 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:21.633466 [ 5777 ] {f14c8d59-e121-47de-87f5-73d3ab7e1ccb} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:21.643237 [ 5777 ] {f14c8d59-e121-47de-87f5-73d3ab7e1ccb} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:21.652845 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (2 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:22.115267 [ 3329 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:22.146955 [ 3435 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:22.228329 [ 3237 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:22.583944 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:23.117212 [ 3169 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:23.148707 [ 3384 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:23.232784 [ 3369 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:23.698478 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:24.119046 [ 3520 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:24.153672 [ 3006 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:24.234867 [ 3343 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:24.608243 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:25.125477 [ 3521 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:25.155935 [ 3092 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:25.236605 [ 3377 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:25.470813 [ 6665 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:26.129064 [ 3200 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:26.157890 [ 3293 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:26.238440 [ 3132 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:26.316413 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:27.131028 [ 3339 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:27.160482 [ 3206 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:27.166434 [ 5777 ] {1c7e4d8a-ab9c-48bd-a966-309abf8de80e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:27.168693 [ 5777 ] {1c7e4d8a-ab9c-48bd-a966-309abf8de80e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:27.173637 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:27.181142 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (3 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:27.217266 [ 29864 ] {7ea5ef68-648e-4916-a677-3ba66a4a7811} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43174) (comment: 02941_variant_type_4.sh) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000012a8200d 22. /build/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) @ 0x0000000012a8766b 23. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:25:27.245728 [ 3268 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:27.245481 [ 29864 ] {7ea5ef68-648e-4916-a677-3ba66a4a7811} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000012a8200d 22. /build/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) @ 0x0000000012a8766b 23. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 24. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:25:27.693380 [ 3661 ] {} test_voa58nn1.replicated_table_detach_all2 (2c708e4b-bd4f-4f46-aa54-d98bdbc0c42c): Part 1_2_2_0 doesn't have metadata version on disk, setting it to 0. It's okay if the part was created by an old version of ClickHouse 2025.06.25 16:25:28.014548 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:28.140328 [ 3191 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:28.163381 [ 3102 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:28.247878 [ 3395 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:28.259802 [ 6985 ] {83ef2181-9c13-4e4f-a59a-233e05a2968a} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE replicated_table_detach_all1 FETCH PARTITION ALL FROM '/clickhouse/tables/test_00753_{database}/replicated_table_detach_all1';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:28.278883 [ 6985 ] {83ef2181-9c13-4e4f-a59a-233e05a2968a} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:29.065957 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:29.143219 [ 3177 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:29.165520 [ 3213 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:29.250099 [ 3451 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:29.502857 [ 6985 ] {96c7ef0e-3e7d-487f-b5d1-f9aaf180a52c} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: -- test PARTITION ALL ALTER TABLE partition_all2 REPLACE PARTITION ALL FROM partition_all;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:29.504864 [ 6985 ] {96c7ef0e-3e7d-487f-b5d1-f9aaf180a52c} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:29.534203 [ 6985 ] {908e83af-ad18-4d89-a723-d48b0f348d81} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all MOVE PARTITION ALL TO TABLE partition_all2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:29.536614 [ 6985 ] {908e83af-ad18-4d89-a723-d48b0f348d81} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:29.707380 [ 6985 ] {f63e238a-fe57-4fbb-bfea-5ff3a450dcea} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 CLEAR INDEX p IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a457b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efea 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:29.717357 [ 6985 ] {f63e238a-fe57-4fbb-bfea-5ff3a450dcea} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a457b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efea 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:29.770476 [ 6985 ] {9c35fed7-7a8d-4d08-892a-394b967ae731} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 CLEAR COLUMN q IN PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a457b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efea 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:29.781466 [ 6985 ] {9c35fed7-7a8d-4d08-892a-394b967ae731} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000127a457b 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153efea 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:30.027470 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:30.085691 [ 6985 ] {331eec0b-097a-4f78-9903-5de413ed0fb8} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 UPDATE q = q + 1 IN PARTITION ALL where p = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116dd33f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&) const @ 0x00000000116e6c5c 7. /build/src/Interpreters/MutationsInterpreter.cpp:702: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e1d65 8. /build/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) @ 0x00000000116df034 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:25:30.091586 [ 6985 ] {331eec0b-097a-4f78-9903-5de413ed0fb8} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000116dd33f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::getPartitionAndPredicateExpressionForMutationCommand(DB::MutationCommand const&) const @ 0x00000000116e6c5c 7. /build/src/Interpreters/MutationsInterpreter.cpp:702: DB::MutationsInterpreter::prepare(bool) @ 0x00000000116e1d65 8. /build/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) @ 0x00000000116df034 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000116de4dd 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f37b 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:25:30.132061 [ 6985 ] {69e559b1-8e54-4322-827d-8dc30c5199a7} executeQuery: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: ALTER TABLE partition_all2 FREEZE PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:30.134617 [ 6985 ] {69e559b1-8e54-4322-827d-8dc30c5199a7} TCPHandler: Code: 344. DB::Exception: Only support DROP/DETACH/ATTACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5025: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x00000000127bef42 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000001153f488 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000001153d32d 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:30.145529 [ 3269 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:30.167822 [ 3059 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:30.251986 [ 3434 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:30.302390 [ 6985 ] {2d41a611-5ed7-4ac0-b2cd-01698e5728ae} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: CHECK TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000012a99026 6. /build/src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x0000000011965476 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:30.305255 [ 6985 ] {2d41a611-5ed7-4ac0-b2cd-01698e5728ae} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::StorageMergeTree::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x0000000012a99026 6. /build/src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x0000000011965476 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:30.556113 [ 6985 ] {c252e300-cc91-4e80-8179-af51df858d71} executeQuery: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: OPTIMIZE TABLE partition_all2 PARTITION ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000012a87431 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:30.573918 [ 6985 ] {c252e300-cc91-4e80-8179-af51df858d71} TCPHandler: Code: 344. DB::Exception: Only Support DETACH PARTITION ALL currently. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:5825: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x00000000127aa2e0 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000012a87431 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:31.073432 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:31.147914 [ 3175 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:31.169802 [ 3048 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:31.254114 [ 3249 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:32.090113 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:32.194036 [ 3130 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:32.197005 [ 3272 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:32.257327 [ 3317 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:32.379484 [ 5777 ] {92605f7b-f7dc-4810-9b0c-a743cb0cef3d} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:32.382446 [ 5777 ] {92605f7b-f7dc-4810-9b0c-a743cb0cef3d} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:32.397762 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (4 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:33.195804 [ 3503 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:33.198944 [ 3321 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:33.263687 [ 3023 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:33.330105 [ 29864 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:34.198091 [ 3490 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:34.265835 [ 3421 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:34.267066 [ 3256 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:34.354643 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:34.798932 [ 22712 ] {88235022-7894-4011-841a-9136cec39cb9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43200) (comment: 02941_variant_type_4.sh) (in query: select v.UInt64 from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:34.801870 [ 22712 ] {88235022-7894-4011-841a-9136cec39cb9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:35.199887 [ 3364 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:35.296541 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:35.307066 [ 3194 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:35.307555 [ 3185 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:36.204362 [ 3060 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:36.227444 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:36.308996 [ 3169 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:36.309686 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.127279 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:37.268159 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.313865 [ 3257 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.313927 [ 3315 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.888961 [ 5777 ] {2e5923ec-fb95-4d5e-916c-65d4c180ef00} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:37.891126 [ 5777 ] {2e5923ec-fb95-4d5e-916c-65d4c180ef00} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.901726 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (5 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:37.922628 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:38.274422 [ 3225 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:38.286237 [ 6985 ] {fbcd7f05-140a-4dc1-9a3e-07d1347b3306} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59190) (comment: 00753_alter_attach.sql) (in query: SELECT * FROM replicated_partition_attach_all ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:25:38.289808 [ 6985 ] {fbcd7f05-140a-4dc1-9a3e-07d1347b3306} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000001319283f 12. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013193cc9 13. /build/contrib/llvm-project/libcxx/include/vector:1454: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000013155a6d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013175143 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:25:38.316320 [ 3433 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:38.317836 [ 3207 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:38.911783 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:38.997842 [ 3621 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1f9b7224-725a-4304-bbc5-0deeb6da8271::202506_1_125_45}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:39.276613 [ 3183 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:39.318226 [ 3351 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:39.319597 [ 3313 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:39.910790 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:40.278644 [ 3172 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:40.324878 [ 3233 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:40.324970 [ 3178 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:40.325181 [ 3463 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:40.841413 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:41.283493 [ 3029 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:41.327088 [ 3194 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:41.327552 [ 3201 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:41.328458 [ 3331 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:41.720363 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:42.285852 [ 3443 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:42.330437 [ 3139 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:42.330857 [ 3489 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:42.333575 [ 3182 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:42.692699 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:43.107290 [ 5777 ] {20961371-1abd-4de1-9489-74d8feae9db5} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:43.109873 [ 5777 ] {20961371-1abd-4de1-9489-74d8feae9db5} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.118130 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (6 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.288037 [ 3254 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.332472 [ 3345 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.332895 [ 3034 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.343573 [ 3133 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:43.721201 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:44.290083 [ 3494 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:44.334666 [ 3450 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:44.335099 [ 3303 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:44.345826 [ 3347 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:44.787528 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:45.303563 [ 3468 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:45.336438 [ 3422 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:45.336891 [ 3131 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:45.347802 [ 3014 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:45.356483 [ 3998 ] {f867cfe9-c82b-4b75-bcaa-74f85ffd4abd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45330) (comment: 02941_variant_type_4.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:25:45.421412 [ 3998 ] {f867cfe9-c82b-4b75-bcaa-74f85ffd4abd} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:25:45.783869 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:46.305597 [ 3185 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:46.338517 [ 3125 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:46.341533 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:46.357448 [ 3344 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:46.838830 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:47.307573 [ 3241 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:47.344244 [ 3169 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:47.344761 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:47.359539 [ 3397 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:47.886406 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:48.309744 [ 3384 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.346404 [ 3032 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.346900 [ 3461 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.361640 [ 3378 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.395033 [ 5777 ] {3efb6624-3e74-446a-be2a-54359c070707} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:48.399337 [ 5777 ] {3efb6624-3e74-446a-be2a-54359c070707} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.417093 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (7 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:48.858251 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:49.123673 [ 3628 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1d51fb3e-a590-4ced-8b53-2573812c4bf0::202506_1_101_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:49.358733 [ 3118 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:49.358937 [ 3428 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:49.360302 [ 3192 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:49.363768 [ 3100 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:49.880969 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:50.378765 [ 3257 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:50.379193 [ 3171 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:50.379496 [ 3022 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:50.386570 [ 3147 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:50.752001 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:51.380849 [ 3145 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:51.381379 [ 3335 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:51.388546 [ 3335 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:51.390442 [ 3017 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:51.749247 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:52.255646 [ 23388 ] {0d8e945b-5e2e-4786-a0fe-05baa1bfdcc3} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45364) (comment: 02941_variant_type_4.sh) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000012a8200d 8. /build/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) @ 0x0000000012a8766b 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:52.286377 [ 23388 ] {0d8e945b-5e2e-4786-a0fe-05baa1bfdcc3} TCPHandler: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000012a8200d 8. /build/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) @ 0x0000000012a8766b 9. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000011957f6f 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:52.389990 [ 3372 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:52.392186 [ 3225 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:52.392345 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:52.402375 [ 3488 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:52.574379 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:53.392039 [ 3359 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:53.404242 [ 3465 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:53.404363 [ 3368 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:53.414143 [ 3151 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:53.434190 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:53.611634 [ 5777 ] {c78c0b9d-bf20-4a7c-bbb5-e4f32e0caed9} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:53.615429 [ 5777 ] {c78c0b9d-bf20-4a7c-bbb5-e4f32e0caed9} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:53.625560 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (8 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:54.251722 [ 23388 ] {f9bfb73f-c4a1-4964-a61b-f417f48fc63e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45532) (comment: 02941_variant_type_4.sh) (in query: select count() from test where isNotNull(v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d792b7 14. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 17. /build/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&) @ 0x000000001282dc54 18. /build/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 @ 0x000000001282aa0e 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 21. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:25:54.371570 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:54.399614 [ 3396 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:54.406591 [ 3425 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:54.409188 [ 3351 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:54.416136 [ 3436 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:54.486741 [ 23388 ] {f9bfb73f-c4a1-4964-a61b-f417f48fc63e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d792b7 14. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 17. /build/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&) @ 0x000000001282dc54 18. /build/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 @ 0x000000001282aa0e 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 21. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d10fb 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 29. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:25:55.304434 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:55.401867 [ 3521 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:55.408583 [ 3377 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:55.411227 [ 3296 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:55.418075 [ 3040 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:56.295839 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:56.406657 [ 3195 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:56.411420 [ 3270 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:56.415545 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:56.432365 [ 3168 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:57.085585 [ 3998 ] {5ab7b828-9389-42b0-abb1-3b86a078c84f} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_9.constrained (8e8b466a-6ca7-4bb2-abab-6bf9c07691ac) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52658) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:57.095810 [ 3998 ] {5ab7b828-9389-42b0-abb1-3b86a078c84f} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_9.constrained (8e8b466a-6ca7-4bb2-abab-6bf9c07691ac) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:57.193565 [ 3998 ] {4811cf48-ec95-4b29-aaf5-1bae590a4ea5} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_9.constrained (8e8b466a-6ca7-4bb2-abab-6bf9c07691ac) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52658) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:57.197199 [ 3998 ] {4811cf48-ec95-4b29-aaf5-1bae590a4ea5} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_9.constrained (8e8b466a-6ca7-4bb2-abab-6bf9c07691ac) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:57.212650 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:57.408590 [ 3104 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:57.413599 [ 3184 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:57.417447 [ 3167 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:57.434766 [ 3509 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:57.729539 [ 3998 ] {5d4d2de0-f33c-4862-8445-046a23e0b3bc} executeQuery: Code: 469. DB::Exception: Constraint `is_censor` for table test_9.constrained (d347b0bc-8a4c-40c6-b014-72398b9af775) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52658) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:57.738041 [ 3998 ] {5d4d2de0-f33c-4862-8445-046a23e0b3bc} TCPHandler: Code: 469. DB::Exception: Constraint `is_censor` for table test_9.constrained (d347b0bc-8a4c-40c6-b014-72398b9af775) is violated at row 2. Expression: (domainWithoutWWW(URL) = 'censor.net'). Column values: URL = 'Hello'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:58.036856 [ 3998 ] {6a728810-c1fc-4e66-be33-d6f5bcb90283} executeQuery: Code: 469. DB::Exception: Constraint `is_utf8` for table test_9.constrained (d347b0bc-8a4c-40c6-b014-72398b9af775) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52658) (comment: 00998_constraints_all_tables.sql) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:58.038629 [ 3998 ] {6a728810-c1fc-4e66-be33-d6f5bcb90283} TCPHandler: Code: 469. DB::Exception: Constraint `is_utf8` for table test_9.constrained (d347b0bc-8a4c-40c6-b014-72398b9af775) is violated at row 3. Expression: (isValidUTF8(URL)). Column values: URL = 'https://censor.net/teÿst'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x0000000010d2a879 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:0: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000012f937e8 5. /build/contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012fad4c9 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000012fad2ff 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012facdfe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 9. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 10. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x0000000012cbec50 12. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb559d 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:25:58.069730 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:58.249959 [ 3998 ] {e6cd614a-dfea-4b67-82aa-419ee2d6b736} executeQuery: Code: 57. DB::Exception: Table test_9.constrained already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52658) (comment: 00998_constraints_all_tables.sql) (in query: CREATE TABLE constrained (URL String, CONSTRAINT is_censor CHECK domainWithoutWWW(URL) = 'censor.net', CONSTRAINT is_utf8 CHECK isValidUTF8(URL)) ENGINE = StripeLog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:58.251719 [ 3998 ] {e6cd614a-dfea-4b67-82aa-419ee2d6b736} TCPHandler: Code: 57. DB::Exception: Table test_9.constrained already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:25:58.410245 [ 3260 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:58.415518 [ 3181 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:58.418943 [ 3062 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:58.436424 [ 3115 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:58.974949 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:25:59.113351 [ 5777 ] {6df54fd3-aa73-4300-98f9-d533f40efd7e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:25:59.118521 [ 5777 ] {6df54fd3-aa73-4300-98f9-d533f40efd7e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.129217 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (9 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.412043 [ 3280 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.417382 [ 3457 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.423446 [ 3248 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.438396 [ 3428 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:25:59.850477 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:00.479674 [ 3222 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:00.480363 [ 3163 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:00.480514 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:00.481486 [ 3008 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:00.604521 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:01.481888 [ 3077 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:01.482510 [ 3110 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:01.483048 [ 3017 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:01.483815 [ 3187 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:01.559914 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:02.487164 [ 3093 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:02.487259 [ 3073 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:02.489766 [ 3006 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:02.490449 [ 3281 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:02.666502 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:03.492487 [ 3477 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:03.494462 [ 3202 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:03.494569 [ 3427 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:03.494717 [ 3409 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:03.699540 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:04.494878 [ 3405 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.496405 [ 3372 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.497334 [ 3405 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.500190 [ 3156 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.501519 [ 5777 ] {61ce2064-05da-4b24-9d34-2e3dd9633c26} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:04.513014 [ 5777 ] {61ce2064-05da-4b24-9d34-2e3dd9633c26} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.553823 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (10 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:04.740525 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:05.496853 [ 3388 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:05.498533 [ 3033 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:05.500667 [ 3033 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:05.505797 [ 3005 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:05.755965 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:06.498749 [ 3418 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:06.500264 [ 3320 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:06.502340 [ 3146 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:06.507700 [ 3328 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:06.537943 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:07.025773 [ 23388 ] {50c541da-40a8-4490-8458-61c872f28235} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 11 ('#'): #. Unrecognized token: '#'. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44524) (comment: 02192_comment_error.sh) (in query: select 42 #), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007032a8d 3. /build/src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000135c87cc 4. /build/src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000135c885e 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d210 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:26:07.035340 [ 23388 ] {50c541da-40a8-4490-8458-61c872f28235} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 11 ('#'): #. Unrecognized token: '#'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000007032a8d 3. /build/src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x00000000135c87cc 4. /build/src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x00000000135c885e 5. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001190d210 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 9. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:07.343838 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:07.500634 [ 3234 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:07.502239 [ 3404 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:07.504151 [ 3404 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:07.509643 [ 3433 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:08.195765 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:08.502908 [ 3358 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:08.504293 [ 3437 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:08.508668 [ 3282 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:08.511665 [ 3415 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.079645 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:09.505365 [ 3460 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.506434 [ 3174 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.522023 [ 3425 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.591517 [ 3123 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.771866 [ 5777 ] {395a3e6f-259d-4542-8a53-ad2b051d3016} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:09.775885 [ 5777 ] {395a3e6f-259d-4542-8a53-ad2b051d3016} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.798291 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (11 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:09.906813 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:10.510733 [ 3375 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:10.510851 [ 3271 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:10.524042 [ 3138 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:10.593659 [ 3072 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:10.873450 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:11.512980 [ 3092 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:11.513491 [ 3521 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:11.528358 [ 3114 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:11.595589 [ 3040 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:11.847861 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:12.517932 [ 3089 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:12.518328 [ 3288 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:12.531405 [ 3223 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:12.599974 [ 3205 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:12.832819 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:13.522720 [ 3261 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:13.522877 [ 3393 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:13.533556 [ 3078 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:13.603012 [ 3090 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:13.764476 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:13.879322 [ 3626 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.019409 [ 3626 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000b61cf0b 4. /build/src/Functions/sleep.h:0: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61ce0b 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61c68c 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41f86 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41d45 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000121bd334 14. /build/src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093edaa7 15. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 21. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 22. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000012960ed0 29. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000001297b4e2 30. /build/src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000012977eeb 31. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x00000000129634cf (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.337925 [ 3624 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.360100 [ 3624 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000b61cf0b 4. /build/src/Functions/sleep.h:0: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61ce0b 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61c68c 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41f86 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41d45 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000121bd334 14. /build/src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093edaa7 15. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 21. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 22. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000012960ed0 29. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000001297b4e2 30. /build/src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000012977eeb 31. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x00000000129634cf (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.526123 [ 3403 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.526563 [ 3028 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.538620 [ 3217 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.604898 [ 3012 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.778847 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:14.795229 [ 3637 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::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.10505.altinitytest (altinity build)) 2025.06.25 16:26:14.817447 [ 3637 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.047353 [ 5777 ] {cb9797bc-db3d-48f3-989e-a65c64d9bed7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:15.055917 [ 5777 ] {cb9797bc-db3d-48f3-989e-a65c64d9bed7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.134958 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (12 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.308679 [ 3638 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.327681 [ 3638 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000b61cf0b 4. /build/src/Functions/sleep.h:0: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61ce0b 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61c68c 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41f86 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41d45 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000121bd334 14. /build/src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093edaa7 15. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 21. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 22. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000012960ed0 29. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000001297b4e2 30. /build/src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000012977eeb 31. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x00000000129634cf (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.516051 [ 3626 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.526991 [ 3626 ] {d8d7c436-08e0-4170-8f2c-ae8f04f28019::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000000b61cf0b 4. /build/src/Functions/sleep.h:0: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000b61ce0b 5. /build/src/Functions/sleep.h:94: DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b61c68c 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41f86 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x0000000011f41d45 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x00000000121bd334 14. /build/src/Functions/if.cpp:0: DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093edaa7 15. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 18. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 19. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 20. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 21. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 22. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 24. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 25. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x0000000012d60a29 26. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x0000000012d6ee9f 27. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x0000000012d6eff9 28. /build/src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000012960ed0 29. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000001297b4e2 30. /build/src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000012977eeb 31. /build/src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x00000000129634cf (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.527691 [ 3176 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.530063 [ 3473 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.540187 [ 3120 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.606909 [ 3031 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:15.635058 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:16.533772 [ 3095 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:16.534099 [ 3198 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:16.544801 [ 3413 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:16.586104 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:16.611471 [ 3255 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:17.538548 [ 3386 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:17.540673 [ 3478 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:17.546999 [ 3027 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:17.548984 [ 22705 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:17.614522 [ 3325 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:18.540391 [ 3314 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:18.544598 [ 3329 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:18.549387 [ 3181 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:18.594501 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:18.617021 [ 3030 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:19.544049 [ 3268 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:19.553085 [ 3148 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:19.555696 [ 3087 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:19.601160 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:19.619651 [ 3123 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.512865 [ 5777 ] {69c557f7-823a-4d65-a4d4-9f2ea8400f56} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:20.522095 [ 5777 ] {69c557f7-823a-4d65-a4d4-9f2ea8400f56} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.535661 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (13 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.548459 [ 3005 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.557442 [ 3159 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.558991 [ 3433 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.621886 [ 3425 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:20.655506 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:21.550576 [ 3320 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:21.560482 [ 3359 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:21.561329 [ 3105 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:21.565372 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:21.624038 [ 3313 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:22.474129 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:22.552823 [ 3328 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:22.562496 [ 3358 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:22.566931 [ 3437 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:22.626174 [ 3518 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:23.357115 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:23.560047 [ 3282 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:23.566775 [ 3415 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:23.571304 [ 3035 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:23.628383 [ 3375 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:24.313374 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:24.564519 [ 3124 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:24.568609 [ 3151 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:24.573071 [ 3075 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:24.632606 [ 3371 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.118897 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:25.566389 [ 3174 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.573555 [ 3285 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.577569 [ 3019 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.637505 [ 3061 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.873972 [ 5777 ] {81a1072e-b0db-449e-aa92-1dfadb0c6542} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:25.898949 [ 5777 ] {81a1072e-b0db-449e-aa92-1dfadb0c6542} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:25.914176 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (14 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:26.008145 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:26.568263 [ 3351 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:26.575534 [ 3271 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:26.581977 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:26.640973 [ 3157 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:26.948555 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:27.570060 [ 3150 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:27.577537 [ 3092 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:27.586250 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:27.642966 [ 3296 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:27.972622 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:28.571907 [ 3193 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:28.581736 [ 3205 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:28.587846 [ 3251 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:28.647713 [ 3430 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:29.001656 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:29.577193 [ 3063 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:29.585058 [ 3390 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:29.592296 [ 3295 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:29.649780 [ 3231 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:30.003312 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:30.579099 [ 3259 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:30.587352 [ 3270 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:30.599723 [ 3081 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:30.653854 [ 3414 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.042912 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:31.326247 [ 5777 ] {26b6dead-3583-4080-9af4-8b506cfb7f03} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:31.333059 [ 5777 ] {26b6dead-3583-4080-9af4-8b506cfb7f03} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.357952 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (15 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.581031 [ 3084 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.589456 [ 3403 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.604692 [ 3028 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.655816 [ 3298 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:31.936867 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:32.583340 [ 3426 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:32.594417 [ 3487 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:32.610893 [ 3099 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:32.660120 [ 3228 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:33.065188 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:33.585538 [ 3333 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:33.596275 [ 3267 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:33.613208 [ 3509 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:33.662629 [ 3515 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:34.055413 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:34.587545 [ 3053 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:34.598016 [ 3459 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:34.615067 [ 3232 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:34.665007 [ 3013 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:35.074275 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:35.589637 [ 3385 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:35.599846 [ 3136 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:35.616907 [ 3130 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:35.673057 [ 3170 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.083351 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:36.592708 [ 3504 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.601500 [ 3032 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.623521 [ 3299 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.676547 [ 3252 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.859269 [ 5777 ] {25634357-851b-4fff-ac61-269002b43066} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:36.870673 [ 5777 ] {25634357-851b-4fff-ac61-269002b43066} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.894775 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (16 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:36.984509 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:37.594696 [ 3417 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:37.603326 [ 3399 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:37.625249 [ 3518 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:37.678830 [ 3288 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:37.908443 [ 2956 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:38.601341 [ 3460 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:38.605388 [ 3365 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:38.627148 [ 3375 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:38.680844 [ 3410 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:38.947720 [ 41880 ] {} test_voa58nn1.replicated_table_detach_all2 (2c708e4b-bd4f-4f46-aa54-d98bdbc0c42c): Table /clickhouse/tables/test_00753_test_voa58nn1/replicated_table_detach_all/replicas/2 is already started to be removing by another replica right now 2025.06.25 16:26:38.981651 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:39.299856 [ 45257 ] {e1c86415-03eb-4c10-8574-03ba6e1184de} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34544) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_voa58nn1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:26:39.302346 [ 45257 ] {e1c86415-03eb-4c10-8574-03ba6e1184de} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.407935 [ 45158 ] {e17da113-2323-4c64-a9c4-ad5453926690} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45404) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_voa58nn1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:26:39.410249 [ 45158 ] {e17da113-2323-4c64-a9c4-ad5453926690} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.478099 [ 3998 ] {921876de-4fc6-44cf-b734-d353a65257c2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45408) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_voa58nn1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:26:39.480672 [ 3998 ] {921876de-4fc6-44cf-b734-d353a65257c2} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.603597 [ 3174 ] {} test_voa58nn1.replicated_partition_attach_all (3e95e399-7102-4220-b082-4179d0d7ddbd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_00753_test_voa58nn1/replicated_partition_attach_all/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.622870 [ 3285 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.629045 [ 3138 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.682854 [ 3088 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:39.854744 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:40.624729 [ 3271 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:40.638939 [ 3496 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:40.684837 [ 3286 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:40.862940 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:41.629250 [ 3371 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:41.647082 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:41.683650 [ 23388 ] {f67048ad-00a0-4b8b-9fe3-23231bcb73b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/af5/af584f45-5658-421b-9a62-90b359d62d9d/all_1_1_0/ in table test_9.t_json_mutations (af584f45-5658-421b-9a62-90b359d62d9d) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56172) (comment: 01825_new_type_json_mutations.sql) (in query: SELECT * FROM t_json_mutations ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000128f85ac 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl 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)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8cfe 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000010cd5bbf 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::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 @ 0x0000000010d7ea70 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::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 @ 0x0000000010cf5d0f 16. /build/src/DataTypes/Serializations/SerializationObject.cpp:0: DB::SerializationObject::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 @ 0x0000000010d43836 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 31. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 2025.06.25 16:26:41.687221 [ 3199 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:41.709550 [ 23388 ] {f67048ad-00a0-4b8b-9fe3-23231bcb73b3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): (while reading column obj): (while reading from part /var/lib/clickhouse/store/af5/af584f45-5658-421b-9a62-90b359d62d9d/all_1_1_0/ in table test_9.t_json_mutations (af584f45-5658-421b-9a62-90b359d62d9d) 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000128f85ac 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl 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)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8cfe 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000010cd5bbf 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::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 @ 0x0000000010d7ea70 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::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 @ 0x0000000010cf5d0f 16. /build/src/DataTypes/Serializations/SerializationObject.cpp:0: DB::SerializationObject::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 @ 0x0000000010d43836 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 18. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 21. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131b7d4f 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 26. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 28. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 29. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 30. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 31. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 2025.06.25 16:26:41.745150 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:42.315005 [ 5777 ] {0d478a63-e8c7-443b-9d0e-c9fd5ab75f4e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:42.318593 [ 5777 ] {0d478a63-e8c7-443b-9d0e-c9fd5ab75f4e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:42.341208 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (17 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:42.631214 [ 3061 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:42.649657 [ 3240 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:42.689362 [ 3430 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:42.832158 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:43.350134 [ 26622 ] {1f0dc277-b49f-44da-b3eb-e65756d59361} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56274) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- this is enough to trigger the regression SELECT throwIf(dummy = 0) FROM remote('127.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.361698 [ 26622 ] {1f0dc277-b49f-44da-b3eb-e65756d59361} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.635780 [ 3246 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:43.651589 [ 3157 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:43.691483 [ 3390 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:43.754404 [ 26622 ] {78bcce22-fd88-4c58-b810-79a9a301c56f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56274) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- these are just in case SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 17. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.760619 [ 26622 ] {78bcce22-fd88-4c58-b810-79a9a301c56f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 17. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.809104 [ 3998 ] {f0d5c272-494a-4352-901c-4dbdd1942ff4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36980) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.811927 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:43.812215 [ 3998 ] {f0d5c272-494a-4352-901c-4dbdd1942ff4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:43.815307 [ 3998 ] {f0d5c272-494a-4352-901c-4dbdd1942ff4} TCPHandler: Client has gone away. 2025.06.25 16:26:43.988620 [ 3998 ] {6572d23e-90ee-4192-b38a-7075db6e0dca} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54984) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.023085 [ 3998 ] {6572d23e-90ee-4192-b38a-7075db6e0dca} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.060680 [ 26622 ] {823071b8-a97d-4840-8d37-bdc0a0387f16} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56274) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.065136 [ 26622 ] {823071b8-a97d-4840-8d37-bdc0a0387f16} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.071658 [ 45249 ] {70f5d8bf-1ae0-46d7-8423-25c8e1786701} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36982) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.074217 [ 45249 ] {70f5d8bf-1ae0-46d7-8423-25c8e1786701} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.396409 [ 23388 ] {68082c46-69e5-4461-9d58-4b6a8e7b1813} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55976) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.401381 [ 23388 ] {68082c46-69e5-4461-9d58-4b6a8e7b1813} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.426380 [ 3998 ] {8eb668c7-fea0-4b74-a279-057250b7ea56} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36890) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.440499 [ 3998 ] {8eb668c7-fea0-4b74-a279-057250b7ea56} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.461767 [ 26622 ] {bab0c1f7-dbae-45a9-af8e-e538929a5978} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56274) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.470174 [ 26622 ] {bab0c1f7-dbae-45a9-af8e-e538929a5978} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.638462 [ 3150 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:44.654135 [ 3265 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:44.693758 [ 3295 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:44.797298 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:44.847015 [ 23388 ] {ee8e95ce-66c4-41fc-8805-193e166a5b96} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55984) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.853388 [ 23388 ] {ee8e95ce-66c4-41fc-8805-193e166a5b96} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.977652 [ 45249 ] {be5c49d1-5823-4d33-b876-454796bc8fb7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36894) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.977519 [ 26622 ] {9604db83-f029-48dd-972b-15cf6d67bb2c} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56274) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.980656 [ 45249 ] {be5c49d1-5823-4d33-b876-454796bc8fb7} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:26:44.987479 [ 26622 ] {9604db83-f029-48dd-972b-15cf6d67bb2c} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/throwIf.cpp:0: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b760f9c 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 11. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 12. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 14. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 19. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/src/Common/Exception.h:0: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000c6b31b5 3. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x0000000012bbeee9 4. /build/src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x0000000012bc57ad 5. /build/src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000012bffe53 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f4f2 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010c1f33a 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:0: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000010c1f061 2025.06.25 16:26:44.998262 [ 45249 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36894, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000c787db0 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000c7882e3 5. /build/src/IO/ReadBuffer.h:71: DB::ReadBuffer::next() @ 0x00000000073acc3b 6. /build/src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x0000000012cb4d50 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:45.640613 [ 3072 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:45.656309 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:45.695935 [ 3338 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:45.874774 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:46.642601 [ 3101 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:46.666293 [ 3284 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:46.697879 [ 3078 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:46.940381 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:47.559236 [ 5777 ] {2b931fff-b376-4040-829b-b615fcdff602} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:47.576873 [ 5777 ] {2b931fff-b376-4040-829b-b615fcdff602} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:47.602343 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (18 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:47.644425 [ 3040 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:47.668429 [ 3452 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:47.701038 [ 3275 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:47.873609 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:48.646299 [ 3089 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:48.705720 [ 3349 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:48.709948 [ 3289 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:48.935305 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:48.951132 [ 45249 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:49.166322 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_148_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:49.648283 [ 3297 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:49.707746 [ 3107 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:49.718630 [ 3259 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:50.097581 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:50.650414 [ 3004 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:50.709589 [ 3144 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:50.720690 [ 3270 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:50.947054 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:51.652589 [ 3247 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:51.711812 [ 3472 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:51.722743 [ 3084 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:51.850293 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:52.431166 [ 3621 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_221_246_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.639389 [ 3639 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_148_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.654840 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.713678 [ 3046 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.724590 [ 3217 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.745400 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:52.776993 [ 5777 ] {a034bf7c-b7d7-40e5-94da-ed49c51ed544} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:52.778921 [ 5777 ] {a034bf7c-b7d7-40e5-94da-ed49c51ed544} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:52.788488 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (19 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:53.571060 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:53.656761 [ 3253 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:53.715608 [ 3142 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:53.726082 [ 3476 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:54.514688 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:54.659063 [ 3506 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:54.717495 [ 3362 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:54.727873 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:54.897453 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_148_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:55.381507 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:55.661195 [ 3255 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:55.719346 [ 3512 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:55.729736 [ 3283 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:56.335203 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:56.662997 [ 3064 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:56.727945 [ 3406 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:56.731502 [ 3314 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.028489 [ 3631 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_149_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.124178 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:57.667329 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.731284 [ 3060 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.733344 [ 3140 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.970409 [ 5777 ] {c85e1ec0-2ebd-4b83-8579-33330ddf8c78} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:26:57.975898 [ 5777 ] {c85e1ec0-2ebd-4b83-8579-33330ddf8c78} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:57.978118 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:57.996198 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (20 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:58.669205 [ 3022 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:58.733661 [ 3007 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:58.735134 [ 3315 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:58.841536 [ 3639 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_149_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:58.920319 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:26:59.671447 [ 3452 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:59.735964 [ 3361 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:59.747186 [ 3236 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:26:59.928690 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:00.673544 [ 3193 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:00.741457 [ 3297 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:00.744091 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:00.749201 [ 3039 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:01.597845 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:01.674692 [ 3288 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:01.744107 [ 3011 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:01.750323 [ 3004 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:02.242289 [ 3998 ] {522ad0a9-c14f-4746-b35c-4e694a779a77} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52986) (comment: 00623_truncate_table_throw_exception.sh) (in query: TRUNCATE TABLE test_truncate.test_view;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:02.244891 [ 3998 ] {522ad0a9-c14f-4746-b35c-4e694a779a77} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:02.501086 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:02.676061 [ 3223 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:02.745520 [ 3259 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:02.751715 [ 3160 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:03.334114 [ 5777 ] {4a1a1be7-bd89-431d-9d00-e89fe468d4f8} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:03.336644 [ 5777 ] {4a1a1be7-bd89-431d-9d00-e89fe468d4f8} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:03.351920 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (21 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:03.542729 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:03.677929 [ 3410 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:03.747709 [ 3144 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:03.753685 [ 3158 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:04.033304 [ 23388 ] {075e1fe1-348d-400f-b414-b7ce8712cd03} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53052) (comment: 00623_truncate_table_throw_exception.sh) (in query: DROP DATABASE IF EXISTS test_truncate;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:27:04.046178 [ 23388 ] {075e1fe1-348d-400f-b414-b7ce8712cd03} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000115752cd 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 8. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 9. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 10. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:27:04.386785 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6041bdce-f4b4-4920-96b7-cf0dbaa6d341::202506_127_149_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/contrib/llvm-project/libcxx/include/optional:260: DB::MergeTask::VerticalMergeStage::createPipeForReadingOneColumn(String const&) const @ 0x0000000012758296 17. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x000000001275897d 18. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x000000001275c038 19. /build/src/Storages/MergeTree/MergeTask.cpp:1004: DB::MergeTask::VerticalMergeStage::execute() @ 0x000000001275bdd9 20. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 21. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 24. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 26. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:04.520432 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:04.680158 [ 3088 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:04.749859 [ 3195 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:04.756278 [ 3037 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:05.520111 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:05.700532 [ 3020 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:05.752147 [ 3067 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:05.758537 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:06.492602 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:06.708414 [ 3390 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:06.754413 [ 3352 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:06.760697 [ 3168 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:07.457969 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:07.710466 [ 3261 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:07.756260 [ 3312 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:07.762217 [ 3309 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:08.433388 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:08.609139 [ 5777 ] {2164e664-4a3d-46b1-9765-36375e796358} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:08.614867 [ 5777 ] {2164e664-4a3d-46b1-9765-36375e796358} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:08.626255 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (22 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:08.712238 [ 3275 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:08.758169 [ 3403 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:08.764137 [ 3028 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:09.308650 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:09.714616 [ 3090 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:09.759955 [ 3346 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:09.765892 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:10.099146 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:10.762051 [ 3517 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:10.767852 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:10.794546 [ 3349 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:10.930999 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:11.764345 [ 3142 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:11.777609 [ 3476 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:11.796321 [ 3336 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:11.806628 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:12.683714 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:12.766437 [ 3473 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:12.782371 [ 3056 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:12.800547 [ 3120 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:13.563945 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:13.768411 [ 3214 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:13.784231 [ 3333 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:13.799717 [ 5777 ] {df7ef3d2-684a-4ad8-b238-e88b80d71a17} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:13.802835 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:13.806337 [ 5777 ] {df7ef3d2-684a-4ad8-b238-e88b80d71a17} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:13.830587 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (23 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:14.440833 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:14.770153 [ 3459 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:14.786218 [ 3232 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:14.805676 [ 3045 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:15.298372 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:15.772099 [ 3304 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:15.788350 [ 3486 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:15.807917 [ 3356 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:16.255888 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:16.774299 [ 3354 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:16.790289 [ 3018 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:16.813302 [ 3294 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:17.109494 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:17.776339 [ 3064 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:17.792411 [ 3394 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:17.815403 [ 3406 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:17.872084 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:18.788052 [ 3490 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:18.794593 [ 3510 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:18.817547 [ 3364 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:18.834106 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:19.022764 [ 5777 ] {42600fdc-2752-4093-ae14-50561b958ac3} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:19.025925 [ 5777 ] {42600fdc-2752-4093-ae14-50561b958ac3} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:19.036447 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (24 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:19.792434 [ 3148 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:19.796702 [ 3087 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:19.819339 [ 3317 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:19.871971 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:20.797541 [ 3222 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:20.800973 [ 3335 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:20.821354 [ 3514 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:20.850277 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:21.723977 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:21.800300 [ 3309 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:21.803520 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:21.823322 [ 3342 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:22.802235 [ 3084 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:22.805713 [ 3482 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:22.816097 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:22.825679 [ 3041 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:23.700408 [ 45257 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:23.804101 [ 3235 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:23.810361 [ 3098 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:23.827886 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:24.243219 [ 5777 ] {7f5ceab9-f9cc-45dc-89ba-5b3dc1092c13} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:24.245763 [ 5777 ] {7f5ceab9-f9cc-45dc-89ba-5b3dc1092c13} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:24.257768 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (25 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:24.593504 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:24.819227 [ 3085 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:24.819337 [ 3162 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:24.830542 [ 3346 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:25.438025 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:25.821691 [ 3353 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:25.821744 [ 3360 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:25.832493 [ 3519 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:26.242197 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:26.823799 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:26.824169 [ 3129 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:26.834602 [ 3245 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:27.218362 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:27.826087 [ 3142 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:27.826309 [ 3212 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:27.839242 [ 3476 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:28.177489 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:28.829052 [ 3134 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:28.827996 [ 3176 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:28.851093 [ 3050 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.111203 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:29.531723 [ 5777 ] {e9b6894c-e08a-40ae-9266-b715df7d7112} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:29.537796 [ 5777 ] {e9b6894c-e08a-40ae-9266-b715df7d7112} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.553203 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (26 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.830803 [ 3473 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.834865 [ 3056 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.853150 [ 3120 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:29.927176 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:30.730430 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:30.835360 [ 3506 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:30.836705 [ 3333 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:30.855240 [ 3411 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:31.775447 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:31.838350 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:31.839197 [ 3508 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:31.857592 [ 3083 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:32.749398 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:32.841669 [ 3189 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:32.842107 [ 3429 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:32.859730 [ 3502 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:33.662694 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:33.844032 [ 3184 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:33.844351 [ 3167 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:33.862001 [ 3509 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:34.597472 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:34.668507 [ 5777 ] {77c006c7-6274-47f3-8d6f-1f1bb620c7a7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:34.671131 [ 5777 ] {77c006c7-6274-47f3-8d6f-1f1bb620c7a7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:34.691416 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (27 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:34.874659 [ 3459 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:34.875255 [ 3232 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:34.876653 [ 3322 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:35.633782 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:35.876829 [ 3070 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:35.877452 [ 3196 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:35.878615 [ 3304 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:36.726628 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:36.886054 [ 3210 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:36.886083 [ 3294 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:36.888126 [ 3255 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:37.885213 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:37.892164 [ 3458 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:37.892470 [ 3175 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:37.892844 [ 3149 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:38.833479 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:38.897360 [ 3314 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:38.897895 [ 3329 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:38.898594 [ 3260 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:39.780767 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:39.899375 [ 3062 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:39.899733 [ 3148 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:39.907814 [ 3087 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.212734 [ 5777 ] {b6d28e55-f4ff-48f1-9f0b-ac18d191038d} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:40.217130 [ 5777 ] {b6d28e55-f4ff-48f1-9f0b-ac18d191038d} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.235000 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (28 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.270811 [ 45249 ] {906d82c1-8816-4e85-9b7e-6a2c2ffdd58e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=5): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50822) (comment: 02516_projections_with_rollup.sql) (in query: -- We are not interested in the result of this query, but it should not produce a logical error. SELECT avg_duration1, avg_duration1 = avg_duration2 FROM ( SELECT sum(bytes), hour, toStartOfHour(datetime) AS hour, avg(duration) AS avg_duration1 FROM video_log GROUP BY hour WITH ROLLUP WITH TOTALS ) LEFT JOIN ( SELECT hour, sum_bytes AS sum_bytes2, avg_duration AS avg_duration2 FROM video_log_result__fuzz_0 ) USING (hour) SETTINGS joined_subquery_requires_alias = 0 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:27:40.294185 [ 45249 ] {906d82c1-8816-4e85-9b7e-6a2c2ffdd58e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=5): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 16. /build/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&) @ 0x000000001282dc54 17. /build/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 @ 0x000000001282aa0e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 23. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 25. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 26. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 27. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 28. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 30. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 2025.06.25 16:27:40.479634 [ 45158 ] {f38f5628-ba07-447a-929e-7353fb540277} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45424) (comment: 00753_alter_attach.sql) (in query: DROP DATABASE IF EXISTS test_voa58nn1 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:27:40.481868 [ 45158 ] {f38f5628-ba07-447a-929e-7353fb540277} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.660262 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:40.901327 [ 3042 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.904643 [ 3412 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:40.912094 [ 3006 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:41.529709 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:41.903284 [ 3161 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:41.906572 [ 3050 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:41.914267 [ 3056 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:42.572530 [ 26622 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:42.905652 [ 3176 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:42.908612 [ 3497 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:42.918874 [ 3214 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:43.024645 [ 23388 ] {cf50a5b4-6049-41dd-99ca-a5dc3681838f} 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.10505.altinitytest (altinity build)) (from [::1]:36230) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.033073 [ 23388 ] {cf50a5b4-6049-41dd-99ca-a5dc3681838f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.154744 [ 23388 ] {a49f6717-076c-4215-98b9-c2b84033255c} 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.10505.altinitytest (altinity build)) (from [::1]:36230) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.159154 [ 23388 ] {a49f6717-076c-4215-98b9-c2b84033255c} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000701b62b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76937a 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.257956 [ 23388 ] {30bc6db1-20db-4c45-8ccb-d6ab088a13df} 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.10505.altinitytest (altinity build)) (from [::1]:36230) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7695fc 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.262079 [ 23388 ] {30bc6db1-20db-4c45-8ccb-d6ab088a13df} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b7695fc 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.387601 [ 23388 ] {0e822154-2d50-4f04-8305-10e976c8ecec} 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.10505.altinitytest (altinity build)) (from [::1]:36230) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76973c 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.392305 [ 23388 ] {0e822154-2d50-4f04-8305-10e976c8ecec} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b76973c 5. /build/src/Functions/IFunction.cpp:491: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000007b6a0db 6. /build/src/Functions/IFunction.cpp:437: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000007b69ca0 7. /build/src/Functions/IFunction.cpp:452: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000007b6a1b4 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000110504cb 9. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 12. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 15. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 18. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 19. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 21. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 24. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 27. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 28. ? @ 0x00007f597a7a2ac3 29. ? @ 0x00007f597a834850 2025.06.25 16:27:43.503259 [ 23388 ] {709ea654-43b1-4c34-8828-792520cf2d7d} 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.10505.altinitytest (altinity build)) (from [::1]:36230) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b7688a2 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:27:43.507147 [ 23388 ] {709ea654-43b1-4c34-8828-792520cf2d7d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/timeSlots.cpp:0: DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b7688a2 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 11. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 16. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 19. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 22. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 23. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 25. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 26. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 27. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 28. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 31. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 2025.06.25 16:27:43.627678 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:43.913954 [ 3473 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:43.914064 [ 3119 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:43.920576 [ 3411 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:44.448815 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:44.548748 [ 3998 ] {68f0c728-c0ea-4cde-8047-39ce7d5e17bf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53760) (comment: 02122_parallel_formatting_PrettySpace.sh) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) group by number with totals order by number limit 190000 format PrettySpace), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:27:44.553168 [ 3998 ] {68f0c728-c0ea-4cde-8047-39ce7d5e17bf} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:27:44.918962 [ 3143 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:44.919594 [ 3031 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:44.922649 [ 3267 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:45.426321 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:45.513710 [ 5777 ] {de44eb85-cf99-480f-a9fd-6d185d0e82a5} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:45.520138 [ 5777 ] {de44eb85-cf99-480f-a9fd-6d185d0e82a5} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:45.537424 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (29 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:45.921164 [ 3362 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:45.924691 [ 3508 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:45.933453 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:46.097230 [ 45249 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:46.595917 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:46.923338 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:46.926945 [ 3423 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:46.944810 [ 3189 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:47.647283 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:47.925343 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:47.928889 [ 3446 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:47.946922 [ 3389 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:48.581149 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:48.917460 [ 23388 ] {ed9511b6-df7c-457e-a1b1-8e5e46d8091b} executeQuery: Code: 36. DB::Exception: Variant type should have at least one nested type. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53896) (comment: 03276_empty_variant_type.sql) (in query: create table test (v Variant()) engine=Variant();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/DataTypes/DataTypeVariant.cpp:0: DB::DataTypeVariant::DataTypeVariant(std::vector, std::allocator>> const&) @ 0x0000000010c71b4f 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::vector, std::allocator>>, void>(std::allocator const&, std::vector, std::allocator>>&&) @ 0x00000000073af798 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::create(std::shared_ptr const&) @ 0x0000000010c7347c 7. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3633b 8. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35dde 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e636 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155083d 11. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:27:48.919931 [ 23388 ] {ed9511b6-df7c-457e-a1b1-8e5e46d8091b} TCPHandler: Code: 36. DB::Exception: Variant type should have at least one nested type. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/DataTypes/DataTypeVariant.cpp:0: DB::DataTypeVariant::DataTypeVariant(std::vector, std::allocator>> const&) @ 0x0000000010c71b4f 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::vector, std::allocator>>, void>(std::allocator const&, std::vector, std::allocator>>&&) @ 0x00000000073af798 6. /build/contrib/llvm-project/libcxx/include/vector:438: DB::create(std::shared_ptr const&) @ 0x0000000010c7347c 7. /build/contrib/llvm-project/libcxx/include/string:1499: std::shared_ptr DB::DataTypeFactory::getImpl(String const&, std::shared_ptr const&) const @ 0x0000000010c3633b 8. /build/src/DataTypes/DataTypeFactory.cpp:87: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000010c35dde 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000001154e636 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000001155083d 11. /build/src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x000000001155731c 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 13. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:27:48.929360 [ 3104 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:48.930955 [ 3184 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:48.951656 [ 3215 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:49.442114 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:49.932458 [ 3370 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:49.933356 [ 3509 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:49.953987 [ 3515 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:50.301361 [ 45249 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:50.755984 [ 5777 ] {a95c6a3c-c03b-4889-b949-a559f15f2c07} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:50.759275 [ 5777 ] {a95c6a3c-c03b-4889-b949-a559f15f2c07} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:50.769190 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (30 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:50.934430 [ 3204 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:50.941515 [ 3053 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:50.957818 [ 3232 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:51.227765 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:51.859983 [ 3998 ] {100d642d-2e04-4ad5-bb78-69390000e03f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53930) (comment: 01838_system_dictionaries_virtual_key_column.sql) (in query: DROP DICTIONARY example_simple_key_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:51.864993 [ 3998 ] {100d642d-2e04-4ad5-bb78-69390000e03f} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:51.936260 [ 3493 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:51.943329 [ 3381 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:51.962202 [ 3462 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:52.233427 [ 3998 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:52.938243 [ 3045 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:52.946200 [ 3180 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:52.964558 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:53.258641 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:53.940393 [ 3070 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:53.955409 [ 3196 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:53.966721 [ 3304 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:54.175366 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:54.941980 [ 3224 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:54.957380 [ 3263 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:54.968500 [ 3209 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:55.095576 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:55.922581 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:55.943642 [ 3464 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:55.958997 [ 3383 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:55.963984 [ 5777 ] {c9f04b36-3b1e-4291-90e1-c2f2a8b19e83} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:27:55.965700 [ 5777 ] {c9f04b36-3b1e-4291-90e1-c2f2a8b19e83} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:55.969882 [ 3394 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:55.973563 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (31 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:56.148326 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:56.792394 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:56.945505 [ 3203 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:56.961105 [ 3481 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:56.971665 [ 3230 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:57.856768 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:57.947637 [ 3260 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:57.963164 [ 3136 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:57.973994 [ 3130 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:58.765564 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:58.950090 [ 3038 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:58.966516 [ 3140 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:58.986108 [ 3420 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:59.640483 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:27:59.951959 [ 3330 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:59.979439 [ 3310 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:27:59.988138 [ 3447 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:00.529138 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:00.953908 [ 3369 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:00.981574 [ 3299 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:00.993433 [ 3179 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:01.365966 [ 5777 ] {82cbc170-7c26-4af9-8307-b21121a405fe} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:01.390579 [ 5777 ] {82cbc170-7c26-4af9-8307-b21121a405fe} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:01.430081 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (32 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:01.531273 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:01.956021 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:01.983869 [ 3101 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:01.995396 [ 3284 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:02.599939 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:02.959069 [ 3262 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:02.986202 [ 3312 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:03.006790 [ 3367 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:03.656579 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:03.961287 [ 3389 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:03.988105 [ 3232 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:04.008434 [ 3334 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:04.714054 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:04.967103 [ 3104 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:04.998473 [ 3082 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:05.010694 [ 3381 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:05.755702 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:05.969673 [ 3370 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:06.000339 [ 3493 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:06.015456 [ 3165 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:06.774131 [ 5777 ] {ed6df3fa-f307-4696-915f-4c228a874056} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:06.774857 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:06.779170 [ 5777 ] {ed6df3fa-f307-4696-915f-4c228a874056} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:06.791602 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (33 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:06.971700 [ 3484 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:07.004652 [ 3180 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:07.017845 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:07.761387 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:07.973806 [ 3509 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:08.009936 [ 3221 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:08.019912 [ 3070 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:08.857992 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:08.975683 [ 3319 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:09.015298 [ 3220 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:09.022033 [ 3196 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:09.875265 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:09.985905 [ 3204 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:10.017457 [ 3413 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:10.024049 [ 3304 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:10.916374 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:10.990812 [ 3198 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:11.019340 [ 3224 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:11.025995 [ 3382 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:11.117426 [ 3638 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fd2434af-e553-40a5-8c46-f5eaa8ed8ef5::202506_1_175_35}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:11.270563 [ 23388 ] {1e8b2147-cf87-41fd-a2f8-47b4f390df1f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54372) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:11.311806 [ 23388 ] {1e8b2147-cf87-41fd-a2f8-47b4f390df1f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:11.992822 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:12.000739 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:12.021208 [ 3263 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:12.027550 [ 3512 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:12.095066 [ 5777 ] {9c06fb22-f506-4920-b436-67f3c0cc0112} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:12.105006 [ 5777 ] {9c06fb22-f506-4920-b436-67f3c0cc0112} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:12.119680 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (34 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:12.995322 [ 3305 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:13.028547 [ 3009 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:13.029921 [ 3467 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:13.030580 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:13.830510 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:13.997247 [ 3079 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:14.030430 [ 3294 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:14.031789 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:14.767131 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:14.999103 [ 3485 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:15.032488 [ 3458 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:15.033574 [ 3175 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:15.668773 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:16.003360 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:16.034596 [ 3149 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:16.035567 [ 3219 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:16.207216 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:16.651363 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:17.036301 [ 3102 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:17.038747 [ 3213 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:17.043523 [ 3406 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:17.428625 [ 5777 ] {4a7baad1-2479-46da-94a3-2020e6d69ff8} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:17.429762 [ 5777 ] {4a7baad1-2479-46da-94a3-2020e6d69ff8} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:17.460713 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (35 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:17.496461 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:18.040040 [ 3181 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:18.040502 [ 3130 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:18.088336 [ 3170 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:18.465085 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:19.042087 [ 3364 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:19.042463 [ 3340 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:19.090206 [ 3057 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:19.435369 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:20.044606 [ 3152 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:20.046246 [ 3148 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:20.092241 [ 3249 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:20.471613 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:21.048735 [ 3443 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:21.049164 [ 3237 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:21.094285 [ 3498 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:21.501969 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:22.051032 [ 3332 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:22.070048 [ 3397 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:22.096488 [ 3032 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:22.397512 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:22.702839 [ 5777 ] {a73bd97c-45c6-45ff-8c89-4bc131a2c566} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:22.710906 [ 5777 ] {a73bd97c-45c6-45ff-8c89-4bc131a2c566} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:22.720485 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (36 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:23.053541 [ 3100 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:23.073772 [ 3392 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:23.101193 [ 3355 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:23.224012 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:24.055622 [ 3507 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:24.068043 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:24.076009 [ 3225 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:24.118646 [ 3240 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:24.892780 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:25.057768 [ 3250 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:25.107115 [ 3309 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:25.120470 [ 3403 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:25.713024 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:26.059585 [ 3283 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:26.108962 [ 3079 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:26.122271 [ 3200 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:26.733889 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:27.062506 [ 3047 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:27.111112 [ 3018 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:27.124201 [ 3339 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:27.702757 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:27.964728 [ 5777 ] {bbf0ab44-866b-4110-86aa-826314025e42} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:27.967469 [ 5777 ] {bbf0ab44-866b-4110-86aa-826314025e42} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:27.982409 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (37 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:28.064951 [ 3210 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:28.113715 [ 3294 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:28.129232 [ 3374 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:28.690479 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:29.059044 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:29.066653 [ 3071 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:29.115616 [ 3456 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:29.131326 [ 3209 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:29.635124 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:30.068496 [ 3305 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:30.118318 [ 3218 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:30.133227 [ 3054 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:30.528356 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:31.070295 [ 3469 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:31.120071 [ 3191 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:31.135253 [ 3177 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:31.471292 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:32.075718 [ 3408 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:32.210415 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:32.210494 [ 3510 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:32.521254 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:33.077504 [ 3291 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:33.212602 [ 3256 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:33.254422 [ 5777 ] {54f0825f-426e-4526-a3c8-e1767599cbb1} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:33.272720 [ 5777 ] {54f0825f-426e-4526-a3c8-e1767599cbb1} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:33.293435 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (38 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:33.299807 [ 3201 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:33.539117 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:34.079472 [ 3386 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:34.215094 [ 3340 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:34.301982 [ 3182 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:34.425620 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:35.081690 [ 3478 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:35.217475 [ 3057 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:35.304084 [ 3155 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:35.392776 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:36.083635 [ 3327 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:36.219419 [ 3060 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:36.306268 [ 3034 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:36.383166 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:37.085761 [ 3458 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:37.221439 [ 3140 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:37.289838 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:37.308328 [ 3450 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:38.063584 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:38.087048 [ 3175 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:38.227628 [ 3036 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:38.310439 [ 3241 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:38.536350 [ 5777 ] {b4c349b9-1bdb-474a-ad15-6aa7ccd4fdf1} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:38.538463 [ 5777 ] {b4c349b9-1bdb-474a-ad15-6aa7ccd4fdf1} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:38.548583 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (39 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:39.030688 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:39.088829 [ 3016 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:39.229810 [ 3062 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:39.322088 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:40.026403 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:40.090872 [ 3337 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:40.234496 [ 3010 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:40.323921 [ 3504 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:40.350446 [ 3632 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d7566a57-dd76-4fb1-a364-95d36c239568::202506_1_145_40}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:41.017839 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:41.092703 [ 3481 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:41.236553 [ 3132 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:41.325521 [ 3355 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:41.845122 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:42.129285 [ 3230 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:42.238346 [ 3243 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:42.327385 [ 3315 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:42.853298 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:43.131239 [ 3314 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:43.242767 [ 3122 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:43.329811 [ 3110 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:43.783907 [ 5777 ] {5fbeba43-7bbd-40b7-a726-a8da505dfce7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:43.801950 [ 5777 ] {5fbeba43-7bbd-40b7-a726-a8da505dfce7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:43.817587 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (40 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:43.888316 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:44.133070 [ 3170 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:44.252101 [ 3395 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:44.331737 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:44.936434 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:45.135308 [ 3272 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:45.254513 [ 3434 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:45.333652 [ 3035 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:45.910807 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:46.224454 [ 3174 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:46.258752 [ 3425 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:46.281379 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:46.346369 [ 3491 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:46.990201 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:47.226870 [ 3037 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:47.261824 [ 3242 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:47.348593 [ 3168 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:47.865384 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:48.228841 [ 3062 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:48.263148 [ 3330 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:48.352292 [ 3112 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:48.630392 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:49.077072 [ 5777 ] {c13f4974-45de-451f-87cd-5780c02ad1a7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:49.078834 [ 5777 ] {c13f4974-45de-451f-87cd-5780c02ad1a7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:49.086993 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (41 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:49.230598 [ 3115 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:49.264419 [ 3116 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:49.354135 [ 3034 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:49.393740 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:50.232789 [ 3439 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:50.265709 [ 3499 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:50.348260 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:50.358963 [ 3238 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:51.234730 [ 3132 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:51.267295 [ 3310 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:51.299318 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:51.367569 [ 3422 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:52.215468 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:52.236670 [ 3243 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:52.271183 [ 3447 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:52.369345 [ 3173 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:53.126180 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:53.238872 [ 3455 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:53.275450 [ 3475 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:53.370990 [ 3197 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.050054 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:54.241985 [ 3379 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.277492 [ 3254 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.372965 [ 3348 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.418579 [ 5777 ] {6b895c75-c9be-422a-a1fb-baefd35a6d2f} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:54.446164 [ 5777 ] {6b895c75-c9be-422a-a1fb-baefd35a6d2f} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.466069 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (42 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:54.925088 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:55.243970 [ 3268 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:55.282122 [ 3273 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:55.375146 [ 3097 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:55.921097 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:56.246422 [ 3395 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:56.286983 [ 3051 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:56.379561 [ 3125 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:56.906282 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:57.248660 [ 3451 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:57.289033 [ 3494 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:57.383686 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:57.693202 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:58.250884 [ 3127 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:58.290814 [ 3489 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:58.385417 [ 3026 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:58.655563 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:59.252595 [ 3434 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:59.292651 [ 3133 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:59.387487 [ 3103 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:59.504718 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:28:59.801053 [ 5777 ] {c954ad05-5547-4f26-8378-641b79bd3617} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:28:59.803531 [ 5777 ] {c954ad05-5547-4f26-8378-641b79bd3617} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:28:59.812546 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (43 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:00.257019 [ 3480 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:00.294449 [ 3450 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:00.379697 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:00.447414 [ 3241 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:01.259418 [ 3087 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:01.296139 [ 3400 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:01.354951 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:01.449048 [ 3495 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:02.268169 [ 3032 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:02.286617 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:02.297912 [ 3392 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:02.450841 [ 3171 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:03.231127 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:03.270148 [ 3121 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:03.299385 [ 3007 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:03.452169 [ 3409 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:04.269380 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:04.271882 [ 3343 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:04.350292 [ 3388 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:04.454376 [ 3308 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:05.093117 [ 5777 ] {23c2a927-296b-44e1-a757-bb3bcc921099} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:05.106088 [ 5777 ] {23c2a927-296b-44e1-a757-bb3bcc921099} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:05.120574 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (44 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:05.265648 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:05.273897 [ 3234 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:05.352577 [ 3240 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:05.456137 [ 3157 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:06.275764 [ 3284 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:06.302528 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:06.356991 [ 3091 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:06.457557 [ 3438 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:07.239685 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:07.286987 [ 3393 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:07.361757 [ 3259 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:07.459288 [ 3037 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:08.231643 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:08.288951 [ 3367 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:08.363880 [ 3084 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:08.464307 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:09.071984 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:09.292767 [ 3165 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:09.369884 [ 3070 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:09.468106 [ 3413 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:10.121758 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:10.294925 [ 3191 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:10.371810 [ 3394 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:10.406735 [ 5777 ] {18bdc988-cc27-4874-bc74-d59f93c9f3b5} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:10.409625 [ 5777 ] {18bdc988-cc27-4874-bc74-d59f93c9f3b5} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:10.420998 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (45 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:10.469897 [ 3293 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:11.174578 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:11.299710 [ 3307 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:11.374477 [ 3131 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:11.475542 [ 3121 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:12.077194 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:12.301867 [ 3254 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:12.378135 [ 3197 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:12.480293 [ 3520 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:13.048115 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:13.304429 [ 3273 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:13.380348 [ 3348 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:13.482107 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:13.946445 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:14.196011 [ 45158 ] {e75a1290-d972-4c0c-9508-5a5488679993} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59214) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:14.202411 [ 45158 ] {e75a1290-d972-4c0c-9508-5a5488679993} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:14.306778 [ 3421 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:14.382455 [ 3097 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:14.484254 [ 3335 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:14.941779 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:15.321435 [ 3287 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:15.384482 [ 3125 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:15.488530 [ 3077 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:15.731920 [ 5777 ] {baa93bb9-31bb-42d1-b437-b460d7993e35} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:15.739195 [ 5777 ] {baa93bb9-31bb-42d1-b437-b460d7993e35} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:15.765619 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (46 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:15.948640 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:16.323936 [ 3233 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:16.389364 [ 3080 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:16.490677 [ 3110 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:16.872023 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:17.326012 [ 3194 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:17.393012 [ 3103 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:17.495623 [ 3477 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:17.748092 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:18.330390 [ 3432 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:18.395303 [ 3169 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:18.498286 [ 3409 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:18.857290 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:19.191570 [ 45158 ] {9c88bda1-4460-4991-bd8e-f1dae8f17864} 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.10505.altinitytest (altinity build)) (from [::1]:53422) (comment: 02724_function_in_left_table_clause_asof_join.sql) (in query: select count(*) from ( select 1 as id, [1, 2, 3] as arr ) as sessions ASOF LEFT JOIN ( select 1 as session_id, 4 as id ) as visitors ON visitors.session_id <= sessions.id AND arrayFirst(a -> a, arrayMap((a) -> a, sessions.arr)) = visitors.id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:29:19.217625 [ 45158 ] {9c88bda1-4460-4991-bd8e-f1dae8f17864} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000011685475 5. /build/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&) @ 0x000000001166e306 6. /build/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&) @ 0x0000000011662ec2 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:29:19.223558 [ 23388 ] {eea67b16-e770-4733-9b96-2335fac2817e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53430) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:19.238773 [ 23388 ] {eea67b16-e770-4733-9b96-2335fac2817e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=763). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:19.334746 [ 3278 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:19.397273 [ 3332 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:19.506522 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:19.852374 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:20.336978 [ 3303 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:20.399513 [ 3032 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:20.508869 [ 3405 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:20.811948 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:21.041112 [ 5777 ] {477206ef-33ba-419d-bac3-17588d92fcfc} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:21.048271 [ 5777 ] {477206ef-33ba-419d-bac3-17588d92fcfc} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:21.060078 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (47 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:21.339097 [ 3498 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:21.403811 [ 3252 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:21.510762 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:21.790095 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:22.354145 [ 3400 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:22.405896 [ 3457 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:22.512629 [ 3507 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:22.871548 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:23.355856 [ 3397 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:23.407866 [ 3412 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:23.514757 [ 3183 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:23.815185 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:24.358071 [ 3424 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:24.409703 [ 3428 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:24.517084 [ 3465 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:24.806287 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:25.360059 [ 3100 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:25.414358 [ 3274 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:25.520564 [ 3065 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:25.752976 [ 23388 ] {fbab72fc-891d-4fa9-97f5-2a36d700779e} executeQuery: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44046) (comment: 03203_count_with_non_deterministic_function.sql) (in query: CREATE TABLE t (`p` UInt8, `x` UInt64) ENGINE = MergeTree PARTITION BY p ORDER BY x SETTINGS index_granularity = 56190, min_bytes_for_wide_part = 0, 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 = 473947121, compact_parts_max_bytes_to_buffer = 474339419, compact_parts_max_granules_to_buffer = 55, compact_parts_merge_max_bytes_to_prefetch_part = 32604336, merge_max_block_size = 19769, old_parts_lifetime = 390., prefer_fetch_merged_part_size_threshold = 3316574514, vertical_merge_algorithm_min_rows_to_activate = 153866, vertical_merge_algorithm_min_columns_to_activate = 21, min_merge_bytes_to_use_direct_io = 7703663196, index_granularity_bytes = 7196449, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 75846, primary_key_compress_block_size = 22652), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:29:25.765907 [ 23388 ] {fbab72fc-891d-4fa9-97f5-2a36d700779e} TCPHandler: Code: 57. DB::Exception: Table test_13.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:29:25.912837 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:26.361751 [ 3073 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.401766 [ 5777 ] {c2d3fe8b-040c-4e8b-9ec3-158e87767a73} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:26.402867 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.404330 [ 5777 ] {c2d3fe8b-040c-4e8b-9ec3-158e87767a73} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.409355 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (48 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.415505 [ 3174 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.509188 [ 45257 ] {2cf72a2f-5d79-4295-b12a-8b6f498b032b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46112) (in query: SELECT 'Pepyaka' ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb19e5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0a24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000012eb04e2 10. /build/src/Processors/Formats/IOutputFormat.cpp:130: DB::IOutputFormat::work() @ 0x0000000012d75ae2 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 16. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:29:26.517796 [ 45257 ] {2cf72a2f-5d79-4295-b12a-8b6f498b032b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012eb19e5 8. /build/contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000012eb0a24 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x0000000012eb04e2 10. /build/src/Processors/Formats/IOutputFormat.cpp:130: DB::IOutputFormat::work() @ 0x0000000012d75ae2 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 12. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 13. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 16. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x0000000012d5eb17 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011914108 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.521872 [ 3123 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:26.700187 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:27.400996 [ 3375 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:27.417697 [ 3371 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:27.523220 [ 3246 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:27.552749 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:28.367839 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:28.404360 [ 3101 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:28.435112 [ 3040 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:28.526582 [ 3288 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:29.173163 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:29.415166 [ 3275 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:29.437025 [ 3113 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:29.528408 [ 3158 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:29.977543 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:30.417864 [ 3352 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:30.442800 [ 3168 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:30.530067 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:30.852197 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:31.474877 [ 3104 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:31.475648 [ 3218 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:31.533069 [ 3458 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:31.807572 [ 54093 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:31.984243 [ 5777 ] {b8be6c6b-2927-4287-b8d7-4205e7d01976} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:31.994236 [ 5777 ] {b8be6c6b-2927-4287-b8d7-4205e7d01976} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:32.021117 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (49 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:32.477134 [ 3483 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:32.478622 [ 3170 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:32.534945 [ 3135 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:32.627603 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:33.479027 [ 3163 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:33.480128 [ 3145 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:33.487806 [ 54093 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:33.536403 [ 3033 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:34.251145 [ 45158 ] {ac7d87a8-59f5-4ed2-a34a-01deb0d06338} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44958) (comment: 01632_tinylog_read_write.sh) (in query: SELECT * FROM test FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:29:34.261399 [ 45158 ] {ac7d87a8-59f5-4ed2-a34a-01deb0d06338} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 2025.06.25 16:29:34.419579 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:34.481126 [ 3222 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:34.483280 [ 3335 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:34.537748 [ 3258 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:35.305628 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:35.482562 [ 3514 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:35.509090 [ 3006 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:35.539380 [ 3444 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:36.123672 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:36.491133 [ 3110 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:36.510680 [ 3427 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:36.541942 [ 3005 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:36.986850 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:37.462588 [ 5777 ] {c9bd0a3d-7d93-47ec-8e31-9961a9b23d7d} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:37.490448 [ 5777 ] {c9bd0a3d-7d93-47ec-8e31-9961a9b23d7d} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:37.502218 [ 3017 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:37.514906 [ 3405 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:37.519816 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (50 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:37.543382 [ 3418 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:37.837217 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:38.508974 [ 3094 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:38.519528 [ 3156 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:38.545537 [ 3146 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:38.833050 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:39.511104 [ 3343 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:39.522003 [ 3507 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:39.547424 [ 3433 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:39.727733 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:40.241201 [ 53873 ] {1e7b4543-d51c-4268-81c7-ac21a164fc95} executeQuery: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50284) (comment: 02364_setting_cross_to_inner_rewrite.sql) (in query: CREATE TABLE t1 ( x Int ) Engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:29:40.244354 [ 53873 ] {1e7b4543-d51c-4268-81c7-ac21a164fc95} TCPHandler: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:29:40.513158 [ 3372 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:40.526073 [ 3359 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:40.549372 [ 3465 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:40.623909 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:41.515321 [ 3055 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:41.528263 [ 3415 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:41.551167 [ 3065 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:41.593006 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:42.487026 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:42.530193 [ 3124 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:42.555356 [ 3368 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:42.584543 [ 3488 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:42.820771 [ 5777 ] {55e43806-ff1d-4a69-b92a-aedc318252d9} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:42.830388 [ 5777 ] {55e43806-ff1d-4a69-b92a-aedc318252d9} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:42.858841 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (51 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:43.366653 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:43.536362 [ 3086 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:43.557457 [ 3109 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:43.586375 [ 3061 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:44.333152 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:44.538047 [ 3240 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:44.559027 [ 3157 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:44.588096 [ 3265 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:45.192781 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:45.504671 [ 23388 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:45.540039 [ 3521 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:45.561417 [ 3377 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:45.591182 [ 3044 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:45.949209 [ 53873 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:46.096306 [ 23388 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:46.425093 [ 23388 ] {ca485b6c-c1e5-4034-a226-b1a55ed627b5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53184) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT data FROM t_json_files ORDER BY file FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:46.462045 [ 23388 ] {ca485b6c-c1e5-4034-a226-b1a55ed627b5} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:46.542174 [ 3091 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:46.563567 [ 3452 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:46.601322 [ 3193 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:47.002804 [ 23388 ] {5d55f7ef-d58d-48b7-b456-aacf7df5b38b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53200) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:47.119942 [ 23388 ] {5d55f7ef-d58d-48b7-b456-aacf7df5b38b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:47.131129 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:47.543863 [ 3288 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:47.565361 [ 3223 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:47.603105 [ 3199 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.037483 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:48.082171 [ 53879 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:48.294622 [ 5777 ] {4813664f-de1d-4a5f-9dcf-a96909d09cdd} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:48.304160 [ 5777 ] {4813664f-de1d-4a5f-9dcf-a96909d09cdd} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.325276 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (52 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.452430 [ 53873 ] {74eea221-1957-4cad-8161-00d9694c9d74} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC, data ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53264) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT data FROM t_json_files ORDER BY file, data FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:48.464999 [ 53873 ] {74eea221-1957-4cad-8161-00d9694c9d74} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC, data ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:48.545851 [ 3419 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.569754 [ 3430 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.605058 [ 3063 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:48.981997 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:48.992215 [ 53873 ] {a6e7b079-9156-4c67-b9b9-f641385f34ce} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53286) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:49.002553 [ 53873 ] {a6e7b079-9156-4c67-b9b9-f641385f34ce} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:49.550764 [ 3261 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:49.571611 [ 3078 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:49.606714 [ 3144 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:49.804270 [ 53873 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:49.870314 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:50.326169 [ 53882 ] {6894a349-f935-4f9a-a1f7-546868fb0d6a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53336) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT data FROM t_json_files ORDER BY file FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:50.339057 [ 53882 ] {6894a349-f935-4f9a-a1f7-546868fb0d6a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT data FROM t_json_files ORDER BY file ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:50.553031 [ 3128 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:50.573660 [ 3250 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:50.610487 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:50.865233 [ 53879 ] {d294639d-19ca-48ba-8ca6-dc3a44719c1b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53358) (comment: 01825_type_json_multiple_files.sh) (in query: SELECT toTypeName(data) FROM t_json_files LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:50.874176 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:50.874078 [ 53879 ] {d294639d-19ca-48ba-8ca6-dc3a44719c1b} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_files' in scope SELECT toTypeName(data) FROM t_json_files LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000078d12ab 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105f8b1 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000110326f9 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 8. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 11. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 12. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 14. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 17. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 20. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 21. ? @ 0x00007f597a7a2ac3 22. ? @ 0x00007f597a834850 2025.06.25 16:29:51.555387 [ 3245 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:51.575631 [ 3301 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:51.614994 [ 3142 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:51.865212 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:52.559630 [ 3362 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:52.577648 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:52.616962 [ 3043 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:52.932782 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:53.561798 [ 3013 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:53.579569 [ 3512 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:53.618448 [ 3283 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:53.666354 [ 5777 ] {cc097e18-a9dd-42b4-a799-0f3317faf01d} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:53.672712 [ 5777 ] {cc097e18-a9dd-42b4-a799-0f3317faf01d} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:53.699362 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (53 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:53.921736 [ 53873 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:54.563831 [ 3464 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:54.581090 [ 3149 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:54.624472 [ 3394 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:54.875730 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:55.568409 [ 3401 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:55.582664 [ 3152 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:55.625880 [ 3087 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:55.774333 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:56.108448 [ 53882 ] {b19c26ba-1056-458d-962c-bc0611ae8d4a} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52232) (comment: 02942_variant_cast.sql) (in query: select 42::UInt32::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x00000000070fce35 5. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f744b 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:56.110637 [ 53882 ] {b19c26ba-1056-458d-962c-bc0611ae8d4a} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x00000000070fce35 5. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f744b 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:56.284425 [ 53882 ] {20043127-bdfa-4603-97ba-524873635afc} executeQuery: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52232) (comment: 02942_variant_cast.sql) (in query: select now()::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x00000000070fce35 5. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f744b 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:56.291735 [ 53882 ] {20043127-bdfa-4603-97ba-524873635afc} TCPHandler: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x00000000070fce35 5. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f744b 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:56.570287 [ 3437 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:56.586456 [ 3124 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:56.628027 [ 3518 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:56.670467 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:57.361337 [ 53882 ] {e4c8353d-0b41-4811-b808-a09fcd4f5b98} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52232) (comment: 02942_variant_cast.sql) (in query: select 'str'::Variant(String, UInt64)::UInt64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000714ea4b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149aa8 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 19. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 20. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 24. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:29:57.367656 [ 53882 ] {e4c8353d-0b41-4811-b808-a09fcd4f5b98} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000714ea4b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149aa8 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/src/Functions/IFunction.h:62: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007024b2a 15. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 17. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 19. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 20. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 21. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 24. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:29:57.533936 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:57.572306 [ 3282 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:57.593720 [ 3368 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:57.642653 [ 3375 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:57.845410 [ 53882 ] {40654a09-f539-428e-8d42-636bd36e69d0} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52232) (comment: 02942_variant_cast.sql) (in query: select CAST(multiIf(number == 1, NULL::Variant(String, UInt64), number == 2, 'Hello'::Variant(String, UInt64), number::Variant(String, UInt64)), 'UInt64') from numbers(6);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000714ea4b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149aa8 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:29:57.860332 [ 53882 ] {40654a09-f539-428e-8d42-636bd36e69d0} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000714ea4b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149aa8 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 26. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:29:58.082753 [ 53882 ] {e0ef5157-639e-4daf-8bf0-5eec97522203} executeQuery: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52232) (comment: 02942_variant_cast.sql) (in query: select 'str'::Variant(String, UInt64)::Variant(String, Array(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x00000000070fdb2f 5. /build/src/Functions/FunctionsConversion.cpp:4298: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f6dad 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:58.085158 [ 53882 ] {e0ef5157-639e-4daf-8bf0-5eec97522203} TCPHandler: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x00000000070fdb2f 5. /build/src/Functions/FunctionsConversion.cpp:4298: DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000070f6dad 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x00000000070f65ae 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105033e 8. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 11. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 14. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 17. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 18. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:29:58.547557 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:58.574144 [ 3415 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:58.595951 [ 3417 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:58.647144 [ 3445 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:59.015355 [ 5777 ] {6eb71758-c0fe-49a2-8847-54b4f0771f54} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:29:59.028488 [ 5777 ] {6eb71758-c0fe-49a2-8847-54b4f0771f54} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:59.039690 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (54 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:59.117830 [ 53882 ] {5a871a83-4142-4744-b298-c300d05a75c3} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52332) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/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) @ 0x000000001226088d 5. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 6. /build/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&) @ 0x000000001166245c 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:29:59.132842 [ 53882 ] {5a871a83-4142-4744-b298-c300d05a75c3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/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) @ 0x000000001226088d 5. /build/src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000116686bf 6. /build/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&) @ 0x000000001166245c 7. /build/src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000001164d930 8. /build/src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001164a77e 9. /build/src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001164896d 10. /build/src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011910a6d 11. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:29:59.446582 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:29:59.576063 [ 3035 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:59.598337 [ 3460 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:29:59.649500 [ 3240 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:00.318070 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:00.580974 [ 3065 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:00.600198 [ 3399 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:00.651592 [ 3150 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:01.190024 [ 53879 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:01.275691 [ 45158 ] {3edbec3a-bd74-4639-be12-c6b91fb21176} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52412) (comment: 02457_key_condition_with_types_that_cannot_be_nullable.sql) (in query: CREATE TABLE test (`Printer` LowCardinality(String), `IntervalStart` DateTime) ENGINE = MergeTree PARTITION BY (hiveHash(Printer), toYear(IntervalStart)) ORDER BY (Printer, IntervalStart) SETTINGS index_granularity = 58738, min_bytes_for_wide_part = 700251807, ratio_of_defaults_for_sparse_serialization = 0.6813324689865112, replace_long_file_name_to_hash = true, max_file_name_length = 55, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 308002509, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 14692550, merge_max_block_size = 19985, old_parts_lifetime = 196., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 42, min_merge_bytes_to_use_direct_io = 5872912613, index_granularity_bytes = 16640924, concurrent_part_removal_threshold = 46, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 31847, primary_key_compress_block_size = 81433), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:30:01.310379 [ 45158 ] {3edbec3a-bd74-4639-be12-c6b91fb21176} TCPHandler: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:30:01.582779 [ 3151 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:01.604379 [ 3285 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:01.660953 [ 3265 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:02.051224 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:02.585916 [ 3075 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:02.606805 [ 3019 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:02.665106 [ 3284 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:02.871256 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:03.587721 [ 3086 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:03.608766 [ 3396 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:03.667085 [ 3491 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:03.838996 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:04.191461 [ 5777 ] {65a38dbf-8f5b-4606-87e9-8591a5e9357b} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:04.192542 [ 5777 ] {65a38dbf-8f5b-4606-87e9-8591a5e9357b} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:04.200097 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (55 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:04.592060 [ 3123 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:04.610193 [ 3351 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:04.621826 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:04.668482 [ 3091 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:05.569446 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:05.593758 [ 3313 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:05.611696 [ 3271 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:05.669937 [ 3452 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:06.511188 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:06.595315 [ 3061 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:06.613520 [ 3072 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:06.674419 [ 3193 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:07.422670 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:07.599455 [ 3114 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:07.615767 [ 3044 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:07.676305 [ 3251 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:08.388446 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:08.601435 [ 3063 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:08.617850 [ 3295 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:08.678345 [ 3090 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:09.267003 [ 53882 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:09.420089 [ 5777 ] {0d8d317f-145e-44e5-9ab1-8303cb77c1bd} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:09.437977 [ 5777 ] {0d8d317f-145e-44e5-9ab1-8303cb77c1bd} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:09.456610 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (56 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:09.603487 [ 3236 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:09.620093 [ 3316 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:09.680249 [ 3011 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:10.183930 [ 45158 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:10.605346 [ 3037 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:10.621976 [ 3186 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:10.682164 [ 3247 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:11.243953 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:11.607391 [ 3367 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:11.623986 [ 3472 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:11.664985 [ 45158 ] {b365c4f8-0a7d-4fa9-a86e-aae19b176f17} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47112) (comment: 01780_column_sparse_pk.sql) (in query: SELECT k, s FROM t_sparse_pk WHERE k = 2 ORDER BY k, s;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d606e0 14. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 17. /build/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&) @ 0x000000001282dc54 18. /build/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 @ 0x000000001282aa0e 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906f7e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 21. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:30:11.670322 [ 45158 ] {b365c4f8-0a7d-4fa9-a86e-aae19b176f17} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/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&) @ 0x00000000128f88dc 12. /build/contrib/llvm-project/libcxx/include/vector:553: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010cd4fc2 13. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000010d606e0 14. /build/src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000010cd52cf 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000128f6544 16. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x00000000128f626c 17. /build/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&) @ 0x000000001282dc54 18. /build/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 @ 0x000000001282aa0e 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906f7e 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 21. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 23. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 24. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 26. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 28. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 31. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 2025.06.25 16:30:11.683618 [ 3403 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:12.185555 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:12.609757 [ 3306 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:12.626065 [ 3012 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:12.685570 [ 3142 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:13.138283 [ 54093 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:13.618939 [ 3333 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:13.628420 [ 3362 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:13.659775 [ 53884 ] {1f1c7fbd-9192-4c9f-adc8-02eff4625ce0} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47142) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149c7b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d666a 17. /build/src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d6b57 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000000c9bd6b2 19. /build/src/Functions/FunctionsExternalDictionaries.h:0: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f9646 20. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 21. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 23. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 24. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 25. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 26. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 27. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 28. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 31. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 2025.06.25 16:30:13.668398 [ 53884 ] {1f1c7fbd-9192-4c9f-adc8-02eff4625ce0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictGet('02176_test_simple_key_dictionary', 'value', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149c7b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d666a 17. /build/src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d6b57 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000000c9bd6b2 19. /build/src/Functions/FunctionsExternalDictionaries.h:0: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000073f9646 20. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 21. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 23. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 24. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 25. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 26. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 27. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 28. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 31. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 2025.06.25 16:30:13.689627 [ 3043 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:13.974282 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:14.469624 [ 53884 ] {73551daa-66d4-477a-8092-e284b867d0d9} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47142) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: SELECT dictHas('02176_test_simple_key_dictionary', [0]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149c7b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d666a 17. /build/src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d6b57 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000000c9bd6b2 19. /build/src/Functions/FunctionsExternalDictionaries.h:284: DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007405a18 20. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 21. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 23. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 24. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 25. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 26. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 27. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 28. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 31. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 2025.06.25 16:30:14.472203 [ 53884 ] {73551daa-66d4-477a-8092-e284b867d0d9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function toUInt64: In scope SELECT dictHas('02176_test_simple_key_dictionary', [0]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007149c7b 5. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 6. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 8. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 11. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 12. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 13. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 14. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d666a 17. /build/src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x00000000118d6b57 18. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000000c9bd6b2 19. /build/src/Functions/FunctionsExternalDictionaries.h:284: DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007405a18 20. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 21. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 22. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 23. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67770 24. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c32 25. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 26. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 27. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 28. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 31. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 2025.06.25 16:30:14.502317 [ 53884 ] {dbb6a930-84a7-415f-b1a3-f601504d3285} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47142) (comment: 02176_dict_get_has_implicit_key_cast.sql) (in query: DROP DICTIONARY 02176_test_simple_key_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:14.503977 [ 53884 ] {dbb6a930-84a7-415f-b1a3-f601504d3285} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011573924 5. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 7. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:14.621022 [ 3239 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:14.630314 [ 3502 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:14.691450 [ 3104 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:14.779086 [ 5777 ] {8a8df07e-f0d9-4860-94e8-cbf580810b24} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:14.784712 [ 5777 ] {8a8df07e-f0d9-4860-94e8-cbf580810b24} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:14.795468 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (57 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:14.880196 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:15.622768 [ 3210 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:15.632504 [ 3325 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:15.693947 [ 3018 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:15.907683 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:16.499145 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:16.624636 [ 3059 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:16.636675 [ 3407 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:16.696207 [ 3481 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:16.919999 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:17.627045 [ 3490 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:17.638549 [ 3510 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:17.699982 [ 3364 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:17.983241 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:18.628789 [ 3169 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:18.643102 [ 3332 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:18.702169 [ 3504 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:19.042377 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:19.630895 [ 3518 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:19.645350 [ 3445 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:19.706619 [ 3393 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:20.064167 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:20.137644 [ 5777 ] {9bc72831-5689-4195-86a6-d03f8eb29149} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:20.140317 [ 5777 ] {9bc72831-5689-4195-86a6-d03f8eb29149} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:20.147322 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (58 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:20.633202 [ 3109 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:20.649602 [ 3246 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:20.708508 [ 3049 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:21.177778 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:21.635555 [ 3371 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:21.651576 [ 3157 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:21.719114 [ 3402 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:22.165578 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:22.637646 [ 3150 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:22.655864 [ 3265 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:22.721301 [ 3474 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:23.090774 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:23.639261 [ 3072 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:23.657894 [ 3092 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:23.723466 [ 3231 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:24.049706 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:24.641163 [ 3521 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:24.659568 [ 3101 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:24.725517 [ 3236 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:25.002869 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:25.496409 [ 5777 ] {1e4deda6-dc76-4e06-9d74-05a8086736b7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:25.498257 [ 5777 ] {1e4deda6-dc76-4e06-9d74-05a8086736b7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:25.521012 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (59 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:25.643053 [ 3114 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:25.661925 [ 3044 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:25.727752 [ 3316 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:26.032843 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:26.645150 [ 3377 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:26.666859 [ 3296 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:26.729806 [ 3113 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:27.009964 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:27.647096 [ 3040 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:27.668806 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:27.735329 [ 3039 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:27.918134 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:28.649462 [ 3089 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:28.673951 [ 3288 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:28.785329 [ 3410 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:28.952199 [ 53884 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:29.654047 [ 3088 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:29.675977 [ 3286 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:29.787280 [ 3367 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.021714 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:30.655388 [ 3251 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.677735 [ 3419 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.703291 [ 5777 ] {f7f81a7b-dc1d-4eb4-9e85-c21a20684982} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:30.722330 [ 5777 ] {f7f81a7b-dc1d-4eb4-9e85-c21a20684982} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.744976 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (60 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.799651 [ 3084 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:30.875286 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:31.657514 [ 3205 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:31.679955 [ 3020 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:31.804407 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:31.902938 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:32.659628 [ 3430 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:32.681979 [ 3338 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:32.806574 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:32.869321 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:33.661765 [ 3081 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:33.683983 [ 3067 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:33.808721 [ 3217 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:33.906060 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:34.674264 [ 3353 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:34.686043 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:34.813754 [ 3227 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:35.007009 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:35.676168 [ 3506 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:35.691709 [ 3214 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:35.815777 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:35.999684 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:36.115311 [ 5777 ] {b9fce9f2-2c4f-4167-acee-3234581b1f75} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:36.118495 [ 5777 ] {b9fce9f2-2c4f-4167-acee-3234581b1f75} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:36.163209 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (61 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:36.677874 [ 3184 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:36.693812 [ 3357 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:36.817891 [ 3213 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:37.017247 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:37.679110 [ 3057 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:37.696911 [ 3060 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:37.820005 [ 3140 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:37.896011 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:38.680631 [ 3022 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:38.698387 [ 3007 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:38.813870 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:38.822031 [ 3520 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:39.682387 [ 3410 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:39.706804 [ 3393 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:39.825430 [ 3041 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:39.848960 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:40.578850 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:40.684319 [ 3088 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:40.708598 [ 3049 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:40.827091 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:41.462053 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:41.516501 [ 5777 ] {d1cc7d88-12f6-4155-8bf0-4f229cbddeaa} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:41.523775 [ 5777 ] {d1cc7d88-12f6-4155-8bf0-4f229cbddeaa} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:41.547639 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (62 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:41.686242 [ 3205 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:41.710213 [ 3261 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:41.830717 [ 3346 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:42.445467 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:42.687947 [ 3251 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:42.711901 [ 3275 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:42.833063 [ 3353 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:43.371269 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:43.689910 [ 3419 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:43.722896 [ 3349 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:43.835088 [ 3360 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:44.326702 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:44.700110 [ 3438 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:44.724750 [ 3474 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:44.838884 [ 3306 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:45.260229 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:45.701944 [ 3430 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:45.727476 [ 3231 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:45.846158 [ 3012 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:46.228427 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:46.703829 [ 3295 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:46.723329 [ 5777 ] {8b3070ce-4ccc-42f3-8a43-b45f88afc6ec} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:46.725808 [ 5777 ] {8b3070ce-4ccc-42f3-8a43-b45f88afc6ec} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:46.729460 [ 3297 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:46.739504 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (63 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:46.848262 [ 3519 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:47.309786 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:47.705742 [ 3361 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:47.730895 [ 3316 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:47.850256 [ 3517 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:48.222611 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:48.707705 [ 3113 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:48.732887 [ 3160 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:48.852843 [ 3376 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:49.119038 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:49.710091 [ 3158 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:49.735006 [ 3037 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:49.848254 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:49.854633 [ 3154 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:50.711949 [ 3067 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:50.737097 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:50.812509 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:50.856619 [ 3120 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:51.721751 [ 3312 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:51.739506 [ 3492 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:51.790618 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:51.859987 [ 3031 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:51.980903 [ 5777 ] {2c523ba0-0fda-4af7-a270-e3ee5fd7c4e6} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:51.987225 [ 5777 ] {2c523ba0-0fda-4af7-a270-e3ee5fd7c4e6} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:52.004727 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (64 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:52.723390 [ 3403 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:52.744244 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:52.760163 [ 53877 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:52.861892 [ 3143 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:53.727274 [ 3098 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:53.742618 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:53.757406 [ 3342 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:53.863806 [ 3506 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:54.728690 [ 3189 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:54.732852 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:54.758700 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:54.865988 [ 3184 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:55.730521 [ 3515 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:55.763229 [ 3322 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:55.902475 [ 53412 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000093eaf6b 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000010885fd3 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885bc8 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveQuery() @ 0x0000000012cc7f53 10. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x0000000012cbda10 11. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x0000000012cb4dca 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:30:55.924246 [ 3354 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:56.463666 [ 45249 ] {482d33d4-a6f2-4edd-a43b-501cc15e0076} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/336/336c5db4-df62-4095-ad38-4c50600b3271/all_1_7_3/ in table test_yturjqkj.test (336c5db4-df62-4095-ad38-4c50600b3271) located on disk default of type local, from mark 0 with max_rows_to_read = 32792): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54054) (comment: 03037_dynamic_merges_1_horizontal_compact_wide_tree.sql) (in query: select count(), dynamicType(d), isDynamicElementInSharedData(d) from test group by dynamicType(d), isDynamicElementInSharedData(d) order by count(), dynamicType(d);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000128f85ac 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl 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)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8cfe 13. /build/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 @ 0x0000000010cdfa61 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::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 @ 0x0000000010d7ea70 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::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 @ 0x0000000010cf5d0f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 17. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 21. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 22. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 23. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 24. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 25. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 27. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 28. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 29. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 30. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 31. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 2025.06.25 16:30:56.553167 [ 45249 ] {482d33d4-a6f2-4edd-a43b-501cc15e0076} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/336/336c5db4-df62-4095-ad38-4c50600b3271/all_1_7_3/ in table test_yturjqkj.test (336c5db4-df62-4095-ad38-4c50600b3271) located on disk default of type local, from mark 0 with max_rows_to_read = 32792): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000128f8141 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x00000000128f85ac 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:401: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl 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)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000128f8cfe 13. /build/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 @ 0x0000000010cdfa61 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationVariant::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 @ 0x0000000010d7ea70 15. /build/contrib/llvm-project/libcxx/include/vector:553: DB::SerializationDynamic::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 @ 0x0000000010cf5d0f 16. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:195: 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) @ 0x00000000128f7c34 17. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128f73c6 18. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000128e2b9f 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x00000000128eb91c 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x00000000128e9b97 21. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000012907b80 22. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x00000000131a2eaf 23. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904af7 24. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 25. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 27. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 28. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 29. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 30. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 31. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 2025.06.25 16:30:56.732697 [ 3323 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:56.765825 [ 3181 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:56.775483 [ 45257 ] {c3e84cd7-12a2-4e2f-932c-f1e4073027ea} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48252) (comment: 03037_dynamic_merges_1_horizontal_compact_wide_tree.sql) (in query: DROP DATABASE IF EXISTS test_yturjqkj ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:30:56.778034 [ 45257 ] {c3e84cd7-12a2-4e2f-932c-f1e4073027ea} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:56.816840 [ 53879 ] {b07770c3-fda6-4367-819d-915a4077c312} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48262) (comment: 03037_dynamic_merges_1_horizontal_compact_wide_tree.sql) (in query: DROP DATABASE IF EXISTS test_yturjqkj ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:30:56.818606 [ 53879 ] {b07770c3-fda6-4367-819d-915a4077c312} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:56.926414 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:57.456496 [ 5777 ] {c06862dd-2aff-4adf-b3e8-72bba950860e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:30:57.459134 [ 5777 ] {c06862dd-2aff-4adf-b3e8-72bba950860e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:57.480575 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (65 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:57.736542 [ 3140 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:57.769280 [ 3010 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:57.928097 [ 3330 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:58.407345 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c944daf9-de77-4918-ae2f-90aeb61f7cdd::202506_1_178_73}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:58.740333 [ 3504 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:58.770785 [ 3032 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:58.930148 [ 3461 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:59.308739 [ 53412 ] {946ab66d-0709-4503-9a92-4c2728e4ffa7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40642) (comment: 00386_enum_in_pk.sql) (in query: SELECT cityHash64(groupArray(d)) FROM enum_pk WHERE exp2(toInt64(d != '1')) > 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:30:59.319863 [ 53412 ] {946ab66d-0709-4503-9a92-4c2728e4ffa7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000012906d45 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x00000000131b4a4e 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x00000000131d5c50 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::MergeTreeSelectProcessor::read() @ 0x0000000012904a7d 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x00000000131a5940 18. /build/contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x0000000012d52d67 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 20. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 21. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d6002c 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:30:59.742139 [ 3011 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:59.772666 [ 3242 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:30:59.942544 [ 3423 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:00.025955 [ 45158 ] {0eaab98d-54e7-4530-acfa-57bda54b3e8f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40694) (comment: 01870_modulo_partition_key.sql) (in query: SELECT 'simple partition key:';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:00.030582 [ 45158 ] {0eaab98d-54e7-4530-acfa-57bda54b3e8f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:00.827642 [ 3041 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:00.830019 [ 3046 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:00.944710 [ 3066 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:01.829278 [ 3085 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:01.831536 [ 3346 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:01.947038 [ 3429 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:02.641028 [ 54093 ] {f63af4fa-2d15-4b1f-b586-a65a348523a5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40714) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 300), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000011702faa 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:31:02.642913 [ 54093 ] {f63af4fa-2d15-4b1f-b586-a65a348523a5} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000011702faa 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:31:02.668666 [ 5777 ] {0189274b-c67a-43e6-8ae3-3882bfef8963} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:02.670825 [ 5777 ] {0189274b-c67a-43e6-8ae3-3882bfef8963} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:02.692588 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (66 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:02.831104 [ 3353 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:02.833090 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:02.950886 [ 3076 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:03.834382 [ 3306 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:03.838019 [ 3012 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:03.952822 [ 3389 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:04.049449 [ 54093 ] {464d0dd8-8d6c-4f72-93d5-5bd19892c2a3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40768) (comment: 00417_kill_query.sh) (in query: SELECT sleep(1) FROM system.numbers LIMIT 301), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000011702faa 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:31:04.053436 [ 54093 ] {464d0dd8-8d6c-4f72-93d5-5bd19892c2a3} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x0000000011702faa 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:31:04.836397 [ 3376 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:04.840465 [ 3129 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:04.954671 [ 3300 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:05.838596 [ 3245 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:05.842404 [ 3301 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:05.956024 [ 3357 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:06.842965 [ 3096 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:06.844148 [ 3426 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:06.959816 [ 3167 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:07.845309 [ 3099 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:07.846201 [ 3228 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:07.962269 [ 3319 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:08.058322 [ 5777 ] {07376629-d819-4e7e-a155-0594006bda70} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:08.060270 [ 5777 ] {07376629-d819-4e7e-a155-0594006bda70} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:08.069698 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (67 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:08.847122 [ 3120 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:08.847797 [ 3119 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:08.965827 [ 3509 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:09.848641 [ 3143 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:09.858346 [ 3506 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:09.967772 [ 3058 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:10.850794 [ 3277 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:10.860229 [ 3508 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:10.969302 [ 3204 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:11.854065 [ 3083 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:11.864672 [ 3459 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:11.970976 [ 3013 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:12.858882 [ 3106 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:12.870358 [ 3283 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:12.981749 [ 3117 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:13.284410 [ 5777 ] {9b2b0acc-b44e-43e2-99fe-ddbca920f73f} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:13.287020 [ 5777 ] {9b2b0acc-b44e-43e2-99fe-ddbca920f73f} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:13.307786 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (68 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:13.333206 [ 53877 ] {62d4d7ed-ab3a-4e7f-a676-b7ec0a7c5840} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60238) (comment: 03020_long_values_pretty_are_not_cut_if_single.sh) (in query: SHOW CREATE TABLE system.metric_log), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:13.346897 [ 53877 ] {62d4d7ed-ab3a-4e7f-a676-b7ec0a7c5840} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=760). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:13.863890 [ 3027 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:13.874523 [ 3500 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:13.983705 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:14.866031 [ 3394 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:14.885146 [ 3406 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:14.985894 [ 3203 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:15.870453 [ 3329 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:15.888839 [ 3260 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:15.987605 [ 3030 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:16.610550 [ 53877 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:16.875204 [ 3439 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:16.891037 [ 3132 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:17.023350 [ 3122 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:17.877583 [ 3116 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:17.893137 [ 3447 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:18.025252 [ 3332 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:18.210353 [ 45249 ] {ff66623d-0285-4122-858f-72be8cb6b22a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02900_buffer_table_alter_race.sh) (in query: /* ddl_entry=query-0000000202 */ DROP TABLE test_11.`02900_buffer` SYNC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:31:18.228868 [ 45249 ] {ff66623d-0285-4122-858f-72be8cb6b22a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40656) (comment: 02900_buffer_table_alter_race.sh) (in query: drop table 02900_buffer), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:31:18.248473 [ 45249 ] {ff66623d-0285-4122-858f-72be8cb6b22a} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000102e477a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001157306f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 7. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 12. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 14. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000011572e61 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000011571814 17. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011570f90 18. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 19. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 20. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 23. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 26. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 2025.06.25 16:31:18.700346 [ 5777 ] {00a0ce51-9d9a-4926-aaf9-a096870fb4e7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:18.705168 [ 5777 ] {00a0ce51-9d9a-4926-aaf9-a096870fb4e7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:18.716319 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (69 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:18.880541 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:18.902970 [ 3248 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:19.027021 [ 3055 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:19.884047 [ 3295 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:19.905277 [ 3298 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:20.028829 [ 3449 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:20.885655 [ 3096 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:20.906939 [ 3050 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:21.035186 [ 3068 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:21.571465 [ 53879 ] {8a2f283e-a766-4aad-ab8c-4f4a235ed9f1} executeQuery: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02691_multiple_joins_backtick_identifiers.sql) (in query: /* ddl_entry=query-0000000207 */ CREATE TABLE test_11.t1 UUID 'ab4b1988-8821-4736-bcd0-f5f8556bcf1f' (`1a` Nullable(Int64), `2b` Nullable(String)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:21.632349 [ 53879 ] {8a2f283e-a766-4aad-ab8c-4f4a235ed9f1} executeQuery: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40758) (comment: 02691_multiple_joins_backtick_identifiers.sql) (in query: CREATE TABLE t1 (`1a` Nullable(Int64), `2b` Nullable(String)) engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:21.649099 [ 53879 ] {8a2f283e-a766-4aad-ab8c-4f4a235ed9f1} TCPHandler: Code: 57. DB::Exception: Table test_11.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:21.887391 [ 3487 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:21.908985 [ 3497 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:22.036897 [ 3486 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:22.275508 [ 53877 ] {e57e145e-4e99-4b25-8be3-2c8cda9c6fb4} executeQuery: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40780) (comment: 01280_ttl_where_group_by_negative.sql) (in query: CREATE TABLE ttl_01280_error (`a` Int, `b` Int, `x` Int64, `y` Int64, `d` DateTime) ENGINE = MergeTree ORDER BY (a, b) TTL d + toIntervalSecond(1) GROUP BY x SET y = max(y) SETTINGS index_granularity = 41447, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 148235307, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 12303692, merge_max_block_size = 10437, old_parts_lifetime = 265., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 68, min_merge_bytes_to_use_direct_io = 5192431173, index_granularity_bytes = 883907, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 23288, primary_key_compress_block_size = 41685), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:273: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124debdd 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.299057 [ 53877 ] {e57e145e-4e99-4b25-8be3-2c8cda9c6fb4} TCPHandler: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:273: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124debdd 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.563702 [ 53877 ] {3744bc95-91fe-40b8-8143-400fda19cccc} executeQuery: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40780) (comment: 01280_ttl_where_group_by_negative.sql) (in query: CREATE TABLE ttl_01280_error (`a` Int, `b` Int, `x` Int64, `y` Int64, `d` DateTime) ENGINE = MergeTree ORDER BY (a, b) TTL d + toIntervalSecond(1) GROUP BY b SET y = max(y) SETTINGS index_granularity = 41447, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 148235307, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 12303692, merge_max_block_size = 10437, old_parts_lifetime = 265., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 68, min_merge_bytes_to_use_direct_io = 5192431173, index_granularity_bytes = 883907, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 23288, primary_key_compress_block_size = 41685), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:273: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124debdd 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.571704 [ 53877 ] {3744bc95-91fe-40b8-8143-400fda19cccc} TCPHandler: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:273: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124debdd 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.807961 [ 53877 ] {6f4d29a1-a77c-401f-90fe-5bc272d98f52} executeQuery: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40780) (comment: 01280_ttl_where_group_by_negative.sql) (in query: CREATE TABLE ttl_01280_error (`a` Int, `b` Int, `x` Int64, `y` Int64, `d` DateTime) ENGINE = MergeTree ORDER BY (a, b) TTL d + toIntervalSecond(1) GROUP BY a, b, x SET y = max(y) SETTINGS index_granularity = 41447, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 148235307, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 12303692, merge_max_block_size = 10437, old_parts_lifetime = 265., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 68, min_merge_bytes_to_use_direct_io = 5192431173, index_granularity_bytes = 883907, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 23288, primary_key_compress_block_size = 41685), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:265: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124ded66 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.811934 [ 53877 ] {6f4d29a1-a77c-401f-90fe-5bc272d98f52} TCPHandler: Code: 450. DB::Exception: TTL Expression GROUP BY key should be a prefix of primary key. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:265: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124ded66 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:22.911018 [ 3473 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:22.944602 [ 3228 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:23.043658 [ 3382 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:23.064444 [ 53877 ] {e69a8e51-b815-49c1-9e5a-e2e59cf3c1dd} executeQuery: Code: 450. DB::Exception: Multiple aggregations set for one column in TTL Expression. (BAD_TTL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40780) (comment: 01280_ttl_where_group_by_negative.sql) (in query: CREATE TABLE ttl_01280_error (`a` Int, `b` Int, `x` Int64, `y` Int64, `d` DateTime) ENGINE = MergeTree ORDER BY (a, b) TTL d + toIntervalSecond(1) GROUP BY a, b SET y = max(y), y = max(y) SETTINGS index_granularity = 41447, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 148235307, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 12303692, merge_max_block_size = 10437, old_parts_lifetime = 265., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 68, min_merge_bytes_to_use_direct_io = 5192431173, index_granularity_bytes = 883907, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 23288, primary_key_compress_block_size = 41685), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:297: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124dede4 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:23.069394 [ 53877 ] {e69a8e51-b815-49c1-9e5a-e2e59cf3c1dd} TCPHandler: Code: 450. DB::Exception: Multiple aggregations set for one column in TTL Expression. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Storages/TTLDescription.cpp:297: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124dede4 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x00000000124df7d7 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:703: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000012a705c7 7. /build/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 @ 0x00000000122537c7 8. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155db57 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 11. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 12. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 15. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 18. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 19. ? @ 0x00007f597a7a2ac3 20. ? @ 0x00007f597a834850 2025.06.25 16:31:23.912854 [ 3119 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:23.915580 [ 54093 ] {4b105f2a-658f-425c-a41c-cb1c59865495} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_3.sh) (in query: /* ddl_entry=query-0000000209 */ CREATE TABLE test_11.test UUID 'af78f007-36a8-4d08-adf1-f99066732ac5' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:23.948841 [ 3429 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:23.948456 [ 54093 ] {4b105f2a-658f-425c-a41c-cb1c59865495} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40822) (comment: 02941_variant_type_3.sh) (in query: create table test (id UInt64, v Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:23.983343 [ 54093 ] {4b105f2a-658f-425c-a41c-cb1c59865495} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:23.969514 [ 5777 ] {251c7ecc-1abf-43f5-86b4-1f6fc4490d09} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:23.994803 [ 5777 ] {251c7ecc-1abf-43f5-86b4-1f6fc4490d09} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:24.014304 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (70 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:24.046132 [ 3224 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:24.915275 [ 3143 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:24.951010 [ 3300 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:25.050791 [ 3137 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:25.924535 [ 3031 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:25.952856 [ 3502 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:26.023421 [ 45257 ] {a3634b77-83e9-4ec3-9b13-b503a83367c6} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37706) (comment: 02941_variant_type_3.sh) (in query: insert into test select number + 400000, number % 2 ? NULL : ('str_' || toString(number))::Variant(String) from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:26.039968 [ 45257 ] {a3634b77-83e9-4ec3-9b13-b503a83367c6} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:26.055985 [ 3318 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:26.678730 [ 53879 ] {d4683969-6edd-45c5-8403-2970e7ba4586} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37786) (comment: 02941_variant_type_3.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:26.689651 [ 53879 ] {d4683969-6edd-45c5-8403-2970e7ba4586} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:26.926679 [ 3508 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:26.954982 [ 3104 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:27.058105 [ 3106 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:27.931347 [ 3423 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:27.956803 [ 3357 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:28.060014 [ 3047 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:28.933636 [ 3083 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:28.958549 [ 3370 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:29.066774 [ 3302 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:29.416796 [ 53879 ] {e96d41aa-2a2e-4b0a-9ca0-3e5002032ca2} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_3.sh) (in query: /* ddl_entry=query-0000000212 */ CREATE TABLE test_11.test UUID 'ffd8ffb4-e555-420f-857a-da1a6cb9ffee' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.06780554354190826, replace_long_file_name_to_hash = false, max_file_name_length = 2, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 526297344, compact_parts_max_granules_to_buffer = 209, compact_parts_merge_max_bytes_to_prefetch_part = 7362405, merge_max_block_size = 23542, old_parts_lifetime = 89., prefer_fetch_merged_part_size_threshold = 8024750747, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 4024299041, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 16000, primary_key_compress_block_size = 66607), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:29.422712 [ 5777 ] {1f9aaf90-c9da-4bda-ba63-5f744c0b78d7} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:29.432592 [ 5777 ] {1f9aaf90-c9da-4bda-ba63-5f744c0b78d7} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:29.458742 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (71 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:29.465426 [ 53879 ] {e96d41aa-2a2e-4b0a-9ca0-3e5002032ca2} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37876) (comment: 02941_variant_type_3.sh) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.06780554354190826, replace_long_file_name_to_hash = false, max_file_name_length = 2, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 526297344, compact_parts_max_granules_to_buffer = 209, compact_parts_merge_max_bytes_to_prefetch_part = 7362405, merge_max_block_size = 23542, old_parts_lifetime = 89., prefer_fetch_merged_part_size_threshold = 8024750747, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 4024299041, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 16000, primary_key_compress_block_size = 66607), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:29.477600 [ 53879 ] {e96d41aa-2a2e-4b0a-9ca0-3e5002032ca2} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:29.935648 [ 3515 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:29.960328 [ 3052 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:30.069102 [ 3467 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:30.662192 [ 53879 ] {d7a82aca-7386-47ac-a327-fdb225c16320} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37936). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37936) (comment: 01114_database_atomic.sh) (in query: SELECT count() FROM system.processes WHERE query_id != queryID() AND current_database = currentDatabase() AND query LIKE '%-- 14101%'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:31:30.682661 [ 53879 ] {d7a82aca-7386-47ac-a327-fdb225c16320} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37936). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000c7887de 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000c789dfa 4. /build/src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x0000000012cc155a 5. /build/src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf4f8 6. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 8. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 12. ? @ 0x00007f597a7a2ac3 13. ? @ 0x00007f597a834850 2025.06.25 16:31:30.689448 [ 53879 ] {d7a82aca-7386-47ac-a327-fdb225c16320} TCPHandler: Client has gone away. 2025.06.25 16:31:30.937699 [ 3053 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:30.974136 [ 3232 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:31.070872 [ 3229 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:31.560325 [ 45257 ] {c27cf705-ec31-4156-8561-30fa86811115} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37908) (comment: 02941_variant_type_3.sh) (in query: insert into test select number + 400000, number % 2 ? NULL : ('str_' || toString(number))::Variant(String) from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:31.584651 [ 45257 ] {c27cf705-ec31-4156-8561-30fa86811115} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:31.708568 [ 53879 ] {a97e4343-d266-4348-bab6-611923adb0d5} executeQuery: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT 1 AS x) AS a INNER JOIN (SELECT 1 AS x, 2 AS y) AS b ON (a.x = b.x) AND (a.y = b.y). Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37950) (comment: 03076_analyzer_multiple_joins_alias.sql) (in query: SELECT * FROM ( SELECT 1 AS x ) AS a INNER JOIN ( SELECT 1 AS x, 2 AS y ) AS b ON (a.x = b.x) AND (a.y = b.y);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:31:31.710837 [ 53879 ] {a97e4343-d266-4348-bab6-611923adb0d5} TCPHandler: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT 1 AS x) AS a INNER JOIN (SELECT 1 AS x, 2 AS y) AS b ON (a.x = b.x) AND (a.y = b.y). Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 10. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 11. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 14. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 17. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 18. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 26. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 27. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 29. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 30. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 31. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 2025.06.25 16:31:31.927517 [ 53879 ] {06f12881-7425-4e20-bd1d-d394d84fb8b2} executeQuery: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT 1 AS x) AS a INNER JOIN (SELECT 1 AS x, 2 AS y) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN (SELECT 3 AS x) AS c ON a.x = c.x. Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37950) (comment: 03076_analyzer_multiple_joins_alias.sql) (in query: SELECT * FROM ( SELECT 1 AS x ) AS a INNER JOIN ( SELECT 1 AS x, 2 AS y ) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN ( SELECT 3 AS x ) AS c ON a.x = c.x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 10. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 11. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 13. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:31:31.933755 [ 45158 ] {8ed69b59-7933-4e74-959d-ed2d19251d92} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38000) (comment: 02941_variant_type_3.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:31.939147 [ 53879 ] {06f12881-7425-4e20-bd1d-d394d84fb8b2} TCPHandler: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT 1 AS x) AS a INNER JOIN (SELECT 1 AS x, 2 AS y) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN (SELECT 3 AS x) AS c ON a.x = c.x. Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 10. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 11. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 13. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:31:31.939461 [ 45158 ] {8ed69b59-7933-4e74-959d-ed2d19251d92} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:31.939745 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:31.978736 [ 3027 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:32.075392 [ 3325 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:32.077353 [ 53879 ] {9cd51c6c-f712-4ad3-adb6-e16de03ef0ec} executeQuery: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT number AS x FROM numbers(10)) AS a INNER JOIN (SELECT number AS x, number AS y FROM numbers(10)) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN (SELECT number AS x FROM numbers(10)) AS c ON a.x = c.x. Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37950) (comment: 03076_analyzer_multiple_joins_alias.sql) (in query: SELECT * FROM ( SELECT number AS x FROM numbers(10) ) AS a INNER JOIN ( SELECT number AS x, number AS y FROM numbers(10) ) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN ( SELECT number AS x FROM numbers(10) ) AS c ON a.x = c.x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 10. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 11. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 13. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:31:32.084352 [ 53879 ] {9cd51c6c-f712-4ad3-adb6-e16de03ef0ec} TCPHandler: Code: 47. DB::Exception: Identifier 'a.y' cannot be resolved from subquery with name a. In scope SELECT * FROM (SELECT number AS x FROM numbers(10)) AS a INNER JOIN (SELECT number AS x, number AS y FROM numbers(10)) AS b ON (a.x = b.x) AND (a.y = b.y) INNER JOIN (SELECT number AS x FROM numbers(10)) AS c ON a.x = c.x. Maybe you meant: ['a.x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000001109330b 4. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000001108d772 5. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108de14 6. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc56 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 8. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108e884 10. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001108fc69 11. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000110919c4 12. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000011046e5e 13. /build/contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103941e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 16. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001104c984 19. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 20. /build/contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110629c9 21. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 22. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000110618a9 23. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000011060507 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5422: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103272e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 27. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 30. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 31. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 2025.06.25 16:31:32.953060 [ 3164 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:32.980646 [ 3327 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:33.079445 [ 3458 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:33.763029 [ 53877 ] {1a8686ea-b0c6-4a1c-897f-3d0aff45afb0} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38044) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:33.774121 [ 53877 ] {1a8686ea-b0c6-4a1c-897f-3d0aff45afb0} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:33.955041 [ 3149 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:33.982379 [ 3219 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:34.081426 [ 3293 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:34.216307 [ 53877 ] {e6ab44ef-b91b-42b5-b956-aa6c3289514f} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56988) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:34.220263 [ 53877 ] {e6ab44ef-b91b-42b5-b956-aa6c3289514f} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:34.765046 [ 5777 ] {33eac437-a857-4a88-95af-73025f181f87} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:34.768533 [ 5777 ] {33eac437-a857-4a88-95af-73025f181f87} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:34.776555 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (72 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:34.815843 [ 53877 ] {780cbdfa-5a22-4eff-b988-79a312441307} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57002) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:34.834175 [ 53877 ] {780cbdfa-5a22-4eff-b988-79a312441307} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:34.968390 [ 3102 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:34.984349 [ 3059 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:35.083420 [ 3181 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:35.419499 [ 53877 ] {f307e56b-05d9-4b2c-b81e-7b58104e0099} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57008) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(1e300);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:35.433924 [ 53877 ] {f307e56b-05d9-4b2c-b81e-7b58104e0099} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:35.970487 [ 3483 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:35.986347 [ 3272 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:35.992386 [ 53877 ] {54af6a69-8ebd-4579-b935-a6bcdc2f02a7} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57020) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-123.456);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:35.999756 [ 53877 ] {54af6a69-8ebd-4579-b935-a6bcdc2f02a7} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:36.085623 [ 3499 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:36.589686 [ 53412 ] {5d68e137-d3a7-45b5-bafe-1eb3f79c0e9f} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57024) (comment: 01054_random_printable_ascii_ubsan.sh) (in query: SELECT randomPrintableASCII(-1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:36.595250 [ 53412 ] {5d68e137-d3a7-45b5-bafe-1eb3f79c0e9f} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000700edab 4. /build/src/Functions/randomPrintableASCII.cpp:0: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b50eccb 5. /build/src/Functions/IFunction.h:448: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000700e34a 6. /build/src/Functions/IFunctionAdaptors.h:28: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070249da 7. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67c8f 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000011051030 11. /build/contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000110391bc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 14. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 17. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 20. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 21. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 23. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 24. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 25. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 26. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 29. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 30. ? @ 0x00007f597a7a2ac3 31. ? @ 0x00007f597a834850 2025.06.25 16:31:36.703390 [ 53877 ] {99af2b73-0c1d-4257-8f31-3e90665224f6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57034) (comment: 02941_variant_type_3.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:36.718864 [ 53877 ] {99af2b73-0c1d-4257-8f31-3e90665224f6} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:36.974295 [ 3032 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:36.988187 [ 3461 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:37.087516 [ 3244 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:37.976171 [ 3248 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:37.990026 [ 3042 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:38.089580 [ 3110 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:38.673931 [ 53877 ] {6151ed50-289b-40bc-85ce-0df785fc3a1f} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_3.sh) (in query: /* ddl_entry=query-0000000214 */ CREATE TABLE test_11.test UUID '356ddf8d-9bbc-44c6-8f16-0e5410ce3d10' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.06780554354190826, replace_long_file_name_to_hash = false, max_file_name_length = 2, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 526297344, compact_parts_max_granules_to_buffer = 209, compact_parts_merge_max_bytes_to_prefetch_part = 7362405, merge_max_block_size = 23542, old_parts_lifetime = 89., prefer_fetch_merged_part_size_threshold = 8024750747, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 4024299041, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 16000, primary_key_compress_block_size = 66607), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:38.697720 [ 53877 ] {6151ed50-289b-40bc-85ce-0df785fc3a1f} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57078) (comment: 02941_variant_type_3.sh) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.06780554354190826, replace_long_file_name_to_hash = false, max_file_name_length = 2, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 526297344, compact_parts_max_granules_to_buffer = 209, compact_parts_merge_max_bytes_to_prefetch_part = 7362405, merge_max_block_size = 23542, old_parts_lifetime = 89., prefer_fetch_merged_part_size_threshold = 8024750747, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 49, min_merge_bytes_to_use_direct_io = 4024299041, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 16000, primary_key_compress_block_size = 66607), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:38.717868 [ 53877 ] {6151ed50-289b-40bc-85ce-0df785fc3a1f} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000010e095b8 12. /build/contrib/llvm-project/libcxx/include/vector:676: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000010de94c6 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000011558563 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 15. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:38.980292 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:38.994617 [ 3055 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:39.091762 [ 3225 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:39.984743 [ 3223 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:40.002015 [ 3419 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:40.117618 [ 3408 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:40.227658 [ 5777 ] {38f3ce25-7786-415b-b277-a4c8a5f5e00e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:40.230626 [ 53412 ] {189da65d-f057-4473-b84b-19d9068dfbaa} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57088) (comment: 02941_variant_type_3.sh) (in query: insert into test select number + 400000, number % 2 ? NULL : ('str_' || toString(number))::Variant(String) from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:40.231246 [ 5777 ] {38f3ce25-7786-415b-b277-a4c8a5f5e00e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:40.238593 [ 53412 ] {189da65d-f057-4473-b84b-19d9068dfbaa} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str_0' as Int32: syntax error at begin of string. Note: there are toInt32OrZero and toInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while converting source column `if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)'))` to destination column b: while executing 'FUNCTION _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')) :: 1, Int32 :: 3) -> _CAST(if(modulo(number, 2), NULL, CAST(concat('str_', toString(number)), 'Variant(String)')), Int32) Int32 : 2'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Functions/FunctionsConversion.cpp:0: DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000007100e1b 4. /build/src/Core/callOnTypeIndex.h:0: bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000719ce6b 5. /build/src/Functions/FunctionsConversion.cpp:2342: DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007197f48 6. /build/src/Functions/IFunctionAdaptors.h:22: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000702497a 7. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 8. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b6871a 9. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007024059 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000711a8f6 12. /build/contrib/llvm-project/libcxx/include/vector:1596: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl 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) @ 0x00000000071030b1 13. /build/contrib/llvm-project/libcxx/include/vector:432: DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000070f8d90 14. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b67ca5 15. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b68689 16. /build/src/Functions/IFunction.cpp:0: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007b69645 17. /build/contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000011197e1d 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000012fadb76 19. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000c90a7d3 20. /build/src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x0000000012d50a69 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x0000000012d6b289 22. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x0000000012d60f30 23. /build/contrib/llvm-project/libcxx/include/vector:547: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x0000000012d611bd 24. /build/src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000012d61b1f 25. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 27. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 29. ? @ 0x00007f597a7a2ac3 30. ? @ 0x00007f597a834850 2025.06.25 16:31:40.254999 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (73 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:40.663602 [ 53882 ] {9d51e00c-bd21-4fcc-8844-cf6d5c11733b} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57106) (comment: 02941_variant_type_3.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:40.666574 [ 53882 ] {9d51e00c-bd21-4fcc-8844-cf6d5c11733b} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:40.987056 [ 3322 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:41.003969 [ 3381 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:41.120019 [ 3108 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:41.713091 [ 53884 ] {65260384-caf6-47a8-b707-ba5213eb7c4f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55816) (comment: 02126_dist_desc.gen.sql) (in query: select count() from system.query_log where type = 'QueryFinish' and not is_initial_query and startsWith(query, 'DESC') and initial_query_id = ( select distinct query_id from system.query_log where log_comment = '127.2 db.name identifier' and current_database = currentDatabase() );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:31:41.720773 [ 53884 ] {65260384-caf6-47a8-b707-ba5213eb7c4f} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128539c5 8. /build/contrib/llvm-project/libcxx/include/vector:961: 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) @ 0x000000001318df44 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001318ce84 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001318cc93 11. /build/src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001321bdfe 12. /build/contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x00000000131fef4f 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x0000000013175728 14. /build/contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000013174f0e 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001164884d 16. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000116485fe 17. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 18. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 19. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 20. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 21. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 24. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 25. ? @ 0x00007f597a7a2ac3 26. ? @ 0x00007f597a834850 2025.06.25 16:31:42.000318 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:42.005991 [ 3165 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:42.122120 [ 3209 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:43.010244 [ 3180 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:43.019068 [ 3045 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:43.124074 [ 3054 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:44.012138 [ 3003 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:44.101845 [ 3221 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:44.128239 [ 3177 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:44.393394 [ 45158 ] {eba190d4-7aa7-4648-a5cb-bf2e71ab1e30} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40606) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:44.405698 [ 45158 ] {eba190d4-7aa7-4648-a5cb-bf2e71ab1e30} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:45.014126 [ 3070 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:45.103821 [ 3516 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:45.123227 [ 53412 ] {cef02c1c-282a-4eea-9dd0-a2038d59c1ff} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40622) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:45.129204 [ 53412 ] {cef02c1c-282a-4eea-9dd0-a2038d59c1ff} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:45.130077 [ 3485 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:45.589520 [ 45158 ] {288156fb-ed72-4dd0-91c4-5a75097774d3} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40652) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:45.595017 [ 45158 ] {288156fb-ed72-4dd0-91c4-5a75097774d3} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:45.612094 [ 53412 ] {304d007e-eb09-45ea-bdcb-c607dbdbf0ce} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40644) (comment: 02941_variant_type_3.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:45.618675 [ 53412 ] {304d007e-eb09-45ea-bdcb-c607dbdbf0ce} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x0000000011066539 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001103ad51 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000011038300 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001105e689 7. /build/contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001103279e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000011031af9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000110313ce 10. /build/contrib/llvm-project/libcxx/include/vector:547: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000011583fca 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000011647f76 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000011646469 13. /build/contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000011648d64 14. /build/src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x00000000115f21e4 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000119108c9 16. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 18. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 19. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 22. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 23. ? @ 0x00007f597a7a2ac3 24. ? @ 0x00007f597a834850 2025.06.25 16:31:45.693744 [ 5777 ] {84ae3326-a72f-4079-a55d-a5fde82c1a13} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:45.704712 [ 5777 ] {84ae3326-a72f-4079-a55d-a5fde82c1a13} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:45.714923 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (74 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:46.018277 [ 3413 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:46.105882 [ 3325 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:46.132135 [ 3175 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:46.160183 [ 53412 ] {18262118-f858-49a7-bf20-e6b9246efb9e} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40676) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:46.166460 [ 53412 ] {18262118-f858-49a7-bf20-e6b9246efb9e} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:46.687150 [ 45249 ] {56f89789-39f0-4ce0-b61d-ab26f0e61a68} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40712) (comment: 01150_ddl_guard_rwr.sh) (in query: DETACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:46.692027 [ 45249 ] {56f89789-39f0-4ce0-b61d-ab26f0e61a68} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:46.775897 [ 45158 ] {1df9473e-63d2-4e82-aa37-a28aa9ed5a1e} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40714) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:46.785545 [ 45158 ] {1df9473e-63d2-4e82-aa37-a28aa9ed5a1e} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:47.021546 [ 3449 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:47.114614 [ 3294 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:47.134543 [ 3464 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:47.150121 [ 45158 ] {9d5d6416-1c18-4d72-8004-11dd6f8e42a7} executeQuery: Code: 82. DB::Exception: Database test_01150 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40722) (comment: 01150_ddl_guard_rwr.sh) (in query: ATTACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:31:47.158694 [ 45158 ] {9d5d6416-1c18-4d72-8004-11dd6f8e42a7} TCPHandler: Code: 82. DB::Exception: Database test_01150 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:31:47.631746 [ 53412 ] {d776855c-0302-46fa-babf-e3b7b42e1fe1} executeQuery: Code: 57. DB::Exception: Table test_13.table_00483 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40700) (comment: 00483_reading_from_array_structure.sql) (in query: create table `table_00483` (date Date, `Struct.Key1` Array(UInt64), `Struct.Key2` Array(UInt64), padding FixedString(16), x UInt64) engine = MergeTree(date, (date), 8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:47.645267 [ 53412 ] {d776855c-0302-46fa-babf-e3b7b42e1fe1} TCPHandler: Code: 57. DB::Exception: Table test_13.table_00483 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f5d1 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:47.859881 [ 45249 ] {fb65f102-59af-4dc8-ab9c-58ff2f162198} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40770) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:47.869618 [ 45249 ] {fb65f102-59af-4dc8-ab9c-58ff2f162198} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:48.022874 [ 3382 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:48.115991 [ 3456 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:48.136179 [ 3383 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:48.387929 [ 45249 ] {0e0123ed-3b69-4f8b-b62b-62b8a32b3fd6} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40786) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:48.391982 [ 45249 ] {0e0123ed-3b69-4f8b-b62b-62b8a32b3fd6} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:49.024588 [ 3467 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:49.122778 [ 3218 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:49.138076 [ 3149 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:49.453772 [ 45158 ] {eec8abf8-39dc-4023-b4e9-edc60a8dede2} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40816) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:49.485088 [ 45158 ] {eec8abf8-39dc-4023-b4e9-edc60a8dede2} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:50.029555 [ 3354 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:50.126309 [ 3219 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:50.143051 [ 3064 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:50.166625 [ 45249 ] {800960f6-baed-4845-a6e7-410de8e9cdfa} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40834) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:50.170188 [ 45249 ] {800960f6-baed-4845-a6e7-410de8e9cdfa} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:50.672427 [ 45158 ] {2473e83d-a29b-461c-91fb-ff0271e743f8} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40856) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:50.688820 [ 45158 ] {2473e83d-a29b-461c-91fb-ff0271e743f8} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:50.890543 [ 5777 ] {90721529-7e00-4e61-9e22-3ff53590864f} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:50.892491 [ 5777 ] {90721529-7e00-4e61-9e22-3ff53590864f} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:50.906676 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (75 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:51.031314 [ 3406 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:51.128633 [ 3102 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:51.145033 [ 3059 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:51.170751 [ 45158 ] {d6bde4a2-d4dc-4fb8-b133-05b1d9e1045e} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40874) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:51.187182 [ 45158 ] {d6bde4a2-d4dc-4fb8-b133-05b1d9e1045e} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:51.881105 [ 54093 ] {74670243-dd02-47fd-a923-d7d48a0b95db} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40904) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:51.901708 [ 54093 ] {74670243-dd02-47fd-a923-d7d48a0b95db} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:52.072920 [ 3203 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:52.131862 [ 3481 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:52.147119 [ 3323 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:52.366021 [ 45249 ] {4965ff3d-431a-40c1-890c-aeea6d1ee9ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40934) (comment: 01150_ddl_guard_rwr.sh) (in query: ATTACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000010db47ed 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010dcac45 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a814 10. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:52.378568 [ 45249 ] {4965ff3d-431a-40c1-890c-aeea6d1ee9ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c708fcd 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000010db47ed 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010dcac45 9. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001156a814 10. /build/contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b180 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:52.535287 [ 45158 ] {ea7d6d7c-4711-457c-ab61-0eb1ad3f2d52} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40946) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:52.547283 [ 45158 ] {ea7d6d7c-4711-457c-ab61-0eb1ad3f2d52} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:53.077289 [ 3314 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:53.068570 [ 45249 ] {3685f18a-ba67-47aa-9835-0a3b0bdfbda3} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40970) (comment: 01150_ddl_guard_rwr.sh) (in query: DETACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574971 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:31:53.106284 [ 45249 ] {3685f18a-ba67-47aa-9835-0a3b0bdfbda3} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000011574971 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 12. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:31:53.136150 [ 3181 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:53.149818 [ 3136 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:53.258230 [ 45158 ] {e106459c-03b9-4cf1-aaeb-712e75a6c329} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40980) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:53.262945 [ 45158 ] {e106459c-03b9-4cf1-aaeb-712e75a6c329} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:54.058068 [ 45249 ] {c9d9e546-4b2a-42a0-a4e9-dd4e73a33cc8} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41014) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:54.059931 [ 45249 ] {c9d9e546-4b2a-42a0-a4e9-dd4e73a33cc8} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:54.079274 [ 3135 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:54.138309 [ 3166 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:54.152746 [ 3276 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:54.591029 [ 45249 ] {cc2739a2-9971-459d-a0e7-1248130ac640} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37866) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:54.598621 [ 45249 ] {cc2739a2-9971-459d-a0e7-1248130ac640} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:55.081383 [ 3060 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:55.142823 [ 3127 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:55.154599 [ 3434 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:55.181218 [ 54093 ] {7d10d07e-cfae-460b-8901-df2a2cd0eaf8} executeQuery: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37894) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:55.190084 [ 54093 ] {7d10d07e-cfae-460b-8901-df2a2cd0eaf8} TCPHandler: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:55.947738 [ 54093 ] {0aab5f24-691c-47fc-9ded-d36d9713c263} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37930) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:55.958915 [ 54093 ] {0aab5f24-691c-47fc-9ded-d36d9713c263} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:56.082852 [ 3475 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:56.144360 [ 3126 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:56.156364 [ 3254 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:56.353661 [ 5777 ] {4331c4d6-b8d0-41a6-be18-eb2acbcbb09f} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:56.364366 [ 5777 ] {4331c4d6-b8d0-41a6-be18-eb2acbcbb09f} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:56.378935 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (76 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:56.403952 [ 53884 ] {c8b8c592-27b8-40a0-97fe-6ee329207b89} executeQuery: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37948) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:56.408304 [ 53884 ] {c8b8c592-27b8-40a0-97fe-6ee329207b89} TCPHandler: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:56.860789 [ 53884 ] {4e467217-f889-4a36-9662-051c4b670db6} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37982) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:56.865156 [ 53884 ] {4e467217-f889-4a36-9662-051c4b670db6} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:57.085305 [ 3400 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:57.146355 [ 3332 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:57.158071 [ 3384 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:57.428738 [ 53884 ] {c4e720df-ddca-47ca-932a-ebee0105526c} executeQuery: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38014) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:57.431075 [ 53884 ] {c4e720df-ddca-47ca-932a-ebee0105526c} TCPHandler: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:58.086943 [ 3280 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:58.148432 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:58.163893 [ 3424 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:58.590350 [ 45257 ] {5261a0b2-074f-4f6c-a0f1-2b7df58a3ad8} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38058) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:58.601790 [ 45257 ] {5261a0b2-074f-4f6c-a0f1-2b7df58a3ad8} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:59.094019 [ 3073 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:59.118581 [ 54093 ] {723c64e3-086e-424c-8c5d-a02bf00f76a9} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38082) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:59.148455 [ 54093 ] {723c64e3-086e-424c-8c5d-a02bf00f76a9} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:31:59.151103 [ 3388 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:59.165816 [ 3404 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:59.216634 [ 53884 ] {d4f23917-3f10-48c1-9124-46dbf456acf3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38102) (comment: 01150_ddl_guard_rwr.sh) (in query: DETACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:59.218827 [ 53884 ] {d4f23917-3f10-48c1-9124-46dbf456acf3} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001157517b 9. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 10. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 11. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 12. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 13. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 14. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 15. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 16. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 19. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 20. ? @ 0x00007f597a7a2ac3 21. ? @ 0x00007f597a834850 2025.06.25 16:31:59.341762 [ 45257 ] {5d376eb1-d8c7-479e-a146-d3a42c6082d2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38090) (comment: 01273_arrow.sh) (in query: SELECT * FROM arrow_types2 ORDER BY int8 FORMAT Arrow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:59.362004 [ 45257 ] {5d376eb1-d8c7-479e-a146-d3a42c6082d2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=785, jobs=759). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d6d469 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x0000000012d6d7d9 9. /build/src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x0000000012cbf3b9 10. /build/src/Server/TCPHandler.cpp:576: DB::TCPHandler::runImpl() @ 0x0000000012cb55c7 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:31:59.623254 [ 53877 ] {60b936d9-2123-4de8-b487-23882743d09b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41722) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_fjwz34bs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:31:59.630145 [ 53877 ] {60b936d9-2123-4de8-b487-23882743d09b} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:31:59.691939 [ 45257 ] {5addce1f-7d4e-4e98-95b4-c6385a22260a} executeQuery: Code: 82. DB::Exception: Database test_01150 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38120) (comment: 01150_ddl_guard_rwr.sh) (in query: ATTACH DATABASE test_01150), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:31:59.693753 [ 45257 ] {5addce1f-7d4e-4e98-95b4-c6385a22260a} TCPHandler: Code: 82. DB::Exception: Database test_01150 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154b790 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 6. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 7. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 10. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 14. ? @ 0x00007f597a7a2ac3 15. ? @ 0x00007f597a834850 2025.06.25 16:31:59.730086 [ 53884 ] {f68bbdff-3816-4ebd-adf6-06a504b26afc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41736) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_fjwz34bs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:31:59.731999 [ 53884 ] {f68bbdff-3816-4ebd-adf6-06a504b26afc} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.001356 [ 54093 ] {c310879c-21ea-4906-8325-4d49a9752847} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41746) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_fjwz34bs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:32:00.007131 [ 54093 ] {c310879c-21ea-4906-8325-4d49a9752847} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.095798 [ 3408 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.153396 [ 3219 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.167797 [ 3213 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.239937 [ 53884 ] {d637c2db-e977-4411-bb9a-5fe0c2234161} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38142) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:00.242493 [ 53884 ] {d637c2db-e977-4411-bb9a-5fe0c2234161} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:00.271778 [ 54093 ] {736c43f5-7582-4cbf-8337-2e4cfab0436d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41756) (comment: 01273_arrow.sh) (in query: DROP DATABASE IF EXISTS test_fjwz34bs ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 2025.06.25 16:32:00.278639 [ 54093 ] {736c43f5-7582-4cbf-8337-2e4cfab0436d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000701202b 4. /build/src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000011179a34 5. /build/src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000001157557e 6. /build/src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000115719e8 7. /build/src/Interpreters/InterpreterDropQuery.cpp:98: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000011571171 8. /build/src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x0000000011570c45 9. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 13. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 14. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 17. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 18. ? @ 0x00007f597a7a2ac3 19. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:00.640005 [ 53884 ] {fb8dbf74-1989-4e48-a72b-fe7d371aec2e} executeQuery: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38158) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:00.641732 [ 53884 ] {fb8dbf74-1989-4e48-a72b-fe7d371aec2e} TCPHandler: Code: 57. DB::Exception: Table test_01150.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:01.073565 [ 53884 ] {2a4e4577-9c96-4ad5-83ea-a3686ad1a5f4} executeQuery: Code: 60. DB::Exception: Table `test_01150`.`t1` doesn't exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38172) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t1 TO test_01150.t2_tmp, test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe98f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:01.075920 [ 53884 ] {2a4e4577-9c96-4ad5-83ea-a3686ad1a5f4} TCPHandler: Code: 60. DB::Exception: Table `test_01150`.`t1` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Databases/DatabasesCommon.cpp:0: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x0000000010e11d0d 5. /build/src/Databases/DatabaseAtomic.cpp:269: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000010dbe98f 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000001160321e 7. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:01.098100 [ 3291 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:01.158081 [ 3293 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:01.171737 [ 3048 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:01.522545 [ 5777 ] {03f0108d-60b9-49ca-a358-5795586af1d5} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:01.534021 [ 5777 ] {03f0108d-60b9-49ca-a358-5795586af1d5} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:01.540714 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (77 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:01.542124 [ 53884 ] {fefbd31f-9d82-4317-90f9-ec5797653be9} executeQuery: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38176) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:01.543501 [ 53884 ] {fefbd31f-9d82-4317-90f9-ec5797653be9} TCPHandler: Code: 81. DB::Exception: Database test_01150 is currently dropped or renamed. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1863: DB::DDLGuard::DDLGuard(std::map, std::allocator>>&, DB::SharedMutex&, std::unique_lock, String const&, String const&) @ 0x000000001118994f 5. /build/contrib/llvm-project/libcxx/include/__mutex_base:143: DB::DatabaseCatalog::getDDLGuard(String const&, String const&) @ 0x000000001117bdc8 6. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterRenameQuery::execute() @ 0x0000000011601cbd 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:02.019647 [ 53884 ] {7bba9ddd-1225-40d7-a352-4f7e0878dc1d} executeQuery: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38178) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:02.023569 [ 53884 ] {7bba9ddd-1225-40d7-a352-4f7e0878dc1d} TCPHandler: Code: 81. DB::Exception: Database test_01150 does not exist. Maybe you meant test_11?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001117a851 5. /build/src/Interpreters/InterpreterRenameQuery.cpp:111: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c91 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:02.100458 [ 3386 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:02.163147 [ 3337 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:02.173589 [ 3407 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:02.984770 [ 53884 ] {7424e0e1-00e4-4f8d-b47c-06fa4e215f5a} executeQuery: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38214) (comment: 01150_ddl_guard_rwr.sh) (in query: RENAME TABLE test_01150.t2 TO test_01150.t1, test_01150.t2_tmp TO test_01150.t2), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:02.986984 [ 53884 ] {7424e0e1-00e4-4f8d-b47c-06fa4e215f5a} TCPHandler: Code: 57. DB::Exception: Table test_01150.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000001092e1cb 4. /build/src/Interpreters/DatabaseCatalog.cpp:728: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x000000001117aefd 5. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000011602c5e 6. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000011601d36 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001190c6dd 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x0000000012cb549b 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::TCPHandler::run() @ 0x0000000012ccbc59 11. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 14. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 2025.06.25 16:32:03.105217 [ 3027 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:03.165045 [ 3059 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:03.175431 [ 3481 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:03.318229 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bde1766a-25bc-4118-bf12-518f2f20b3dc::202506_1_205_43}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:04.107537 [ 3079 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:04.167111 [ 3324 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:04.180449 [ 3323 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:05.110112 [ 3354 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:05.169204 [ 3230 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:05.182659 [ 3329 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:05.778178 [ 3242 ] {} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000111824a4 9. /build/contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000011182997 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:06.112512 [ 3018 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:06.171424 [ 3431 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:06.189313 [ 3435 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:06.734784 [ 5777 ] {42351e17-5381-4cf7-a883-828c0578a19c} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:06.737902 [ 5777 ] {42351e17-5381-4cf7-a883-828c0578a19c} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:06.750021 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (78 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:07.114560 [ 3456 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:07.173456 [ 3260 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:07.191296 [ 3136 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:08.121318 [ 3327 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:08.176121 [ 3181 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:08.219716 [ 3170 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:09.123374 [ 3339 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:09.178155 [ 3511 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:09.224835 [ 3060 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:10.125552 [ 3209 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:10.189391 [ 3030 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:10.227242 [ 3115 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:11.129853 [ 3464 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:11.191544 [ 3135 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:11.230950 [ 3439 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:11.993331 [ 5777 ] {72c90c62-fae3-40d2-810d-2a1b553e0251} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:11.995342 [ 5777 ] {72c90c62-fae3-40d2-810d-2a1b553e0251} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:12.005532 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (79 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:12.132319 [ 3149 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:12.193792 [ 3490 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:12.286887 [ 3233 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:13.136949 [ 3064 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:13.198286 [ 3510 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:13.289212 [ 3194 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:14.138921 [ 3340 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:14.202728 [ 3420 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:14.291137 [ 3278 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:15.143279 [ 3480 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:15.204991 [ 3152 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:15.293272 [ 3173 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:16.145442 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:16.209274 [ 3026 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:16.295366 [ 3397 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:17.150177 [ 3504 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:17.211389 [ 3244 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:17.298537 [ 5777 ] {a4e9ee4b-55b3-40c4-affd-6572bbab7ae2} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:17.300031 [ 3369 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:17.301631 [ 5777 ] {a4e9ee4b-55b3-40c4-affd-6572bbab7ae2} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:17.310442 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (80 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:18.152306 [ 3192 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:18.225315 [ 3355 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:18.302256 [ 3315 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:19.154305 [ 3077 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:19.229194 [ 3110 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:19.304300 [ 3187 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:20.156293 [ 3488 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:20.230939 [ 3225 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:20.309413 [ 3207 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:21.158390 [ 3270 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:21.302935 [ 3128 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:21.311456 [ 3250 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:22.169191 [ 3028 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:22.305119 [ 3353 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:22.313571 [ 3227 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:22.660662 [ 5777 ] {abf32940-0f23-486e-aea1-843cf69e0e03} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:22.662791 [ 5777 ] {abf32940-0f23-486e-aea1-843cf69e0e03} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:22.680457 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (81 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:23.171327 [ 3052 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:23.307040 [ 3204 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:23.320579 [ 3322 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:24.180879 [ 3407 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:24.311870 [ 3051 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:24.322942 [ 3178 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:25.188411 [ 3260 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:25.316826 [ 3468 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:25.324980 [ 3233 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:26.190528 [ 3136 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:26.319913 [ 3463 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:26.326914 [ 3194 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:26.785238 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:27.193022 [ 3130 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:27.321976 [ 3185 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:27.329176 [ 3201 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:27.951110 [ 5777 ] {4520ded8-87f1-4002-a0c7-a64628c87e7a} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:27.953968 [ 5777 ] {4520ded8-87f1-4002-a0c7-a64628c87e7a} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:27.963854 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (82 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:28.195120 [ 3511 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:28.323845 [ 3331 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:28.341150 [ 3139 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:29.197379 [ 3483 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:29.325968 [ 3432 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:29.343017 [ 3182 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:30.199579 [ 3030 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:30.328419 [ 3112 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:30.344833 [ 3345 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:31.202097 [ 3503 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:31.330446 [ 3034 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:31.346689 [ 3278 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:32.204657 [ 3166 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:32.334726 [ 3303 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:32.348775 [ 3238 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:33.176182 [ 5777 ] {9814e519-bf9b-4170-a3fc-b1d6e3ad45f2} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:33.178014 [ 5777 ] {9814e519-bf9b-4170-a3fc-b1d6e3ad45f2} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:33.187278 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (83 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:33.206793 [ 3276 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:33.336606 [ 3014 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:33.350669 [ 3197 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:34.208620 [ 3490 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:34.338917 [ 3266 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:34.352783 [ 3097 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:35.217059 [ 3256 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:35.341206 [ 3103 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:35.354956 [ 3344 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:36.226697 [ 3038 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:36.343501 [ 3241 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:36.359660 [ 3400 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:37.230680 [ 3036 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:37.345764 [ 3384 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:37.363388 [ 3032 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:38.232804 [ 3243 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:38.348168 [ 3461 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:38.368397 [ 3244 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:38.406909 [ 5777 ] {b54318c5-42e0-4753-af91-2b7a554d7a9d} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:38.411149 [ 5777 ] {b54318c5-42e0-4753-af91-2b7a554d7a9d} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:38.421685 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (84 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:39.235126 [ 3455 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:39.350313 [ 3366 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:39.379146 [ 3280 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:40.237483 [ 3122 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:40.352160 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:40.381180 [ 3042 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:41.240410 [ 3479 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:41.353897 [ 3171 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:41.383045 [ 3121 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:42.242479 [ 3434 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:42.355550 [ 3008 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:42.385107 [ 3110 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:43.244410 [ 3087 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:43.362168 [ 3093 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:43.387456 [ 3073 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:43.696452 [ 5777 ] {40230dda-93c4-42ea-92b5-1e0d89cf2e26} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:43.698496 [ 5777 ] {40230dda-93c4-42ea-92b5-1e0d89cf2e26} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:43.710232 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (85 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:44.246411 [ 3507 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:44.364324 [ 3183 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:44.389501 [ 3418 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:45.248615 [ 3328 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:45.367342 [ 3404 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:45.391460 [ 3433 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:46.250690 [ 3341 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:46.369554 [ 3438 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:46.402266 [ 3063 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:47.252905 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:47.371746 [ 3028 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:47.404767 [ 3298 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:48.255554 [ 3519 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:48.374050 [ 3253 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:48.406980 [ 3376 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.005242 [ 5777 ] {16451cfb-6288-45fb-a637-5c6cee2ff1e2} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:49.007949 [ 5777 ] {16451cfb-6288-45fb-a637-5c6cee2ff1e2} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.017886 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (86 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.257723 [ 3095 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.375492 [ 3173 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.408423 [ 3366 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:49.738980 [ 3629 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8615fb30-d08c-48c1-a41a-01099e1320ba::202506_1_195_39}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:50.263226 [ 3317 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:50.377638 [ 3266 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:50.507731 [ 3477 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:51.265489 [ 3330 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:51.379788 [ 3348 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:51.512529 [ 3343 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:52.268291 [ 3211 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:52.384754 [ 3097 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:52.514770 [ 3372 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:53.270915 [ 3310 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:53.389448 [ 3125 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:53.517377 [ 3156 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:54.273239 [ 3326 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:54.352655 [ 5777 ] {d7eff8b6-822c-4c45-abb4-0272992bccfb} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:54.354487 [ 5777 ] {d7eff8b6-822c-4c45-abb4-0272992bccfb} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:54.363584 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (87 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:54.394349 [ 3080 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:54.522695 [ 3183 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:55.275088 [ 3029 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:55.396123 [ 3332 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:55.527259 [ 3111 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:56.280166 [ 3443 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:56.398522 [ 3504 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:56.531463 [ 3015 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:57.283470 [ 3237 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:57.400302 [ 3378 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:57.533542 [ 3258 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:58.285601 [ 3273 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:58.402478 [ 3369 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:58.538258 [ 3033 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:59.287910 [ 3468 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:59.404578 [ 3226 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:59.542850 [ 3444 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:59.674163 [ 5777 ] {ec930757-174a-41f0-a028-945458537243} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:32:59.676467 [ 5777 ] {ec930757-174a-41f0-a028-945458537243} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:32:59.685458 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (88 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:00.292715 [ 3421 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:00.406554 [ 3299 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:00.544797 [ 3005 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:01.295256 [ 3287 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:01.410929 [ 3442 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:01.550864 [ 3024 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:02.299087 [ 3450 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:02.413215 [ 3457 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:02.553618 [ 3328 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:03.334850 [ 3103 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:03.418109 [ 3248 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:03.558237 [ 3159 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:04.336868 [ 3441 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:04.424273 [ 3042 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:04.560763 [ 3105 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:04.932575 [ 5777 ] {ad286b30-560a-483e-9ca5-51c11ecc911c} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:04.934818 [ 5777 ] {ad286b30-560a-483e-9ca5-51c11ecc911c} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:04.945751 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (89 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:05.338708 [ 3412 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:05.428286 [ 3392 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:05.562904 [ 3465 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:06.341232 [ 3355 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:06.430488 [ 3274 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:06.564682 [ 3358 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:07.344084 [ 3017 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:07.432868 [ 3187 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:07.566815 [ 3124 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:08.346456 [ 3094 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:08.437602 [ 3207 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:08.568689 [ 3020 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:09.348625 [ 3186 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:09.439772 [ 3247 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:09.570541 [ 3262 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:10.213847 [ 5777 ] {69b0eff1-bb43-4c7f-ad06-cbf0d93da7d3} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:10.217352 [ 5777 ] {69b0eff1-bb43-4c7f-ad06-cbf0d93da7d3} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:10.268317 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (90 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:10.350713 [ 3085 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:10.441942 [ 3346 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:10.573045 [ 3306 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:11.355191 [ 3176 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:11.447085 [ 3214 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:11.575412 [ 3333 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:12.357394 [ 3052 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:12.449350 [ 3458 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:12.580833 [ 3059 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:13.359536 [ 3455 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:13.453641 [ 3122 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:13.585831 [ 3148 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:14.361535 [ 3238 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:14.456164 [ 3495 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:14.588116 [ 3368 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:15.363723 [ 3347 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:15.445050 [ 5777 ] {461698d8-b7bf-475c-b5d2-2904a3db1b50} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:15.446968 [ 5777 ] {461698d8-b7bf-475c-b5d2-2904a3db1b50} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:15.457592 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (91 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:15.457967 [ 3416 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:15.590771 [ 3151 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:16.366216 [ 3422 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:16.460011 [ 3264 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:16.592676 [ 3417 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:17.368354 [ 3131 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:17.462520 [ 3069 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:17.594963 [ 3075 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:18.369797 [ 3173 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:18.467272 [ 3074 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:18.597709 [ 3086 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:19.412187 [ 3080 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:19.469929 [ 3171 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:19.624286 [ 3123 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:20.418159 [ 3442 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:20.517880 [ 3488 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:20.626277 [ 3375 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:20.717536 [ 5777 ] {55c6041a-513a-4bab-88b7-949afbffecaa} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:20.720380 [ 5777 ] {55c6041a-513a-4bab-88b7-949afbffecaa} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:20.730831 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (92 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:21.420296 [ 3248 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:21.519938 [ 3507 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:21.628447 [ 3109 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:22.422696 [ 3042 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:22.522470 [ 3225 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:22.630411 [ 3496 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:23.424809 [ 3100 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:23.524814 [ 3015 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:23.632568 [ 3371 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:24.427060 [ 3192 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:24.527512 [ 3033 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:24.637247 [ 3150 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:25.432732 [ 3179 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:25.532792 [ 3444 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:25.639418 [ 3072 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:26.000113 [ 5777 ] {b17be431-3441-4cff-a97a-827c496d0d6c} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:26.002817 [ 5777 ] {b17be431-3441-4cff-a97a-827c496d0d6c} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:26.014212 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (93 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:26.435059 [ 3392 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:26.534777 [ 3024 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:26.641691 [ 3114 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:27.437602 [ 3355 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:27.536709 [ 3418 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:27.653551 [ 3419 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:28.441612 [ 3350 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:28.538810 [ 3328 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:28.657406 [ 3341 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:29.443785 [ 3274 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:29.541567 [ 3234 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:29.659758 [ 3349 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:30.446057 [ 3163 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:30.544097 [ 3207 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:30.662236 [ 3081 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:31.247758 [ 5777 ] {8a3bd3ed-6cbc-4113-bf68-1ece6fd340a4} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:31.250894 [ 5777 ] {8a3bd3ed-6cbc-4113-bf68-1ece6fd340a4} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:31.281114 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (94 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:31.450899 [ 3145 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:31.557130 [ 3159 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:31.664617 [ 3247 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:32.456139 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:32.559456 [ 3105 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:32.671278 [ 3414 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:33.458630 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:33.562234 [ 3465 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:33.673763 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:34.463863 [ 3388 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:34.564815 [ 3437 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:34.675813 [ 3176 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:35.465945 [ 3198 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:35.567006 [ 3458 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:35.677859 [ 3337 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:36.467959 [ 3364 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:36.569479 [ 3010 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:36.620402 [ 5777 ] {4cdd4117-0852-4b1f-a9ca-a00eabc94f90} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:36.622581 [ 5777 ] {4cdd4117-0852-4b1f-a9ca-a00eabc94f90} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:36.640247 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (95 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:36.682001 [ 3223 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:37.470281 [ 3171 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:37.571482 [ 3282 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:37.684412 [ 3410 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:38.472485 [ 3007 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:38.573622 [ 3415 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:38.686760 [ 3088 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:39.474617 [ 3188 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:39.576303 [ 3035 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:39.688803 [ 3205 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:40.479831 [ 3145 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:40.579547 [ 3308 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:40.691179 [ 3251 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:41.482280 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:41.584721 [ 3417 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:41.693480 [ 3341 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:41.810395 [ 5777 ] {3cf0ea8e-79f6-492f-9676-3697b85e0e0e} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:41.813294 [ 5777 ] {3cf0ea8e-79f6-492f-9676-3697b85e0e0e} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:41.830028 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (96 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:42.484330 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:42.586730 [ 3075 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:42.695291 [ 3438 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:43.550814 [ 3292 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:43.588427 [ 3460 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:43.697411 [ 3430 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:44.553628 [ 3320 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:44.592902 [ 3174 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:44.702325 [ 3390 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:45.560075 [ 3159 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:45.597984 [ 3396 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:45.704588 [ 3338 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:46.562604 [ 3105 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:46.600571 [ 3425 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:46.710127 [ 3261 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:46.866576 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:47.136717 [ 5777 ] {70a8b63e-bc17-4ebe-a6b0-585566c69ee2} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:47.138807 [ 5777 ] {70a8b63e-bc17-4ebe-a6b0-585566c69ee2} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:47.162691 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (97 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:47.570832 [ 3358 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:47.603406 [ 3436 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:47.712677 [ 3349 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:48.575757 [ 3313 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:48.608809 [ 3138 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:48.718056 [ 3231 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:49.647308 [ 3371 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:49.649015 [ 3445 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:49.719980 [ 3236 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:50.649861 [ 3521 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:50.661696 [ 3114 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:50.722086 [ 3195 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:51.651599 [ 3040 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:51.663859 [ 3128 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:51.724387 [ 3352 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:52.518551 [ 5777 ] {7b2b78a2-0b95-4d3a-9d47-0b69b5ef7a65} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:52.521498 [ 5777 ] {7b2b78a2-0b95-4d3a-9d47-0b69b5ef7a65} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:52.533907 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (98 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:52.653859 [ 3168 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:52.666011 [ 3021 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:52.726413 [ 3492 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:53.665361 [ 3403 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:53.671514 [ 3028 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:53.730676 [ 3235 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:54.667774 [ 3217 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:54.673774 [ 3517 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:54.732900 [ 3301 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:55.670254 [ 3161 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:55.675844 [ 3176 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:55.737075 [ 3473 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:56.672741 [ 3232 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:56.680389 [ 3198 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:56.739609 [ 3462 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:57.682422 [ 3413 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:57.731988 [ 3079 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:57.741747 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:57.791288 [ 5777 ] {d79bc55d-8f00-4da5-8a68-7753a8d4e6c1} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:33:57.793179 [ 5777 ] {d79bc55d-8f00-4da5-8a68-7753a8d4e6c1} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:57.802197 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (99 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:58.686716 [ 3181 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:58.733755 [ 3166 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:58.743597 [ 3256 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:59.688497 [ 3451 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:59.735495 [ 3434 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:33:59.746038 [ 3152 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:00.690651 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:00.740213 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:00.751157 [ 3121 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:01.702609 [ 3205 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:01.748622 [ 3107 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:01.753972 [ 3160 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:02.706151 [ 3393 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:02.750764 [ 3004 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:02.756691 [ 3144 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:03.022325 [ 5777 ] {46c8cabb-f81e-4807-a26e-b3e884c4fe49} executeQuery: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03206_replication_lag_metric.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 2025.06.25 16:34:03.024814 [ 5777 ] {46c8cabb-f81e-4807-a26e-b3e884c4fe49} DDLWorker(rdb2): Query /* ddl_entry=query-0000000003 */ CREATE TABLE rdb2.t UUID '3c88d60e-a2de-4d80-b1b3-24faf63d56d3' (`id` UInt32) ENGINE = ReplicatedMergeTree ORDER BY id SETTINGS index_granularity = 39964, min_bytes_for_wide_part = 804415463, 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 = 94012939, compact_parts_max_bytes_to_buffer = 196553358, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 24436193, merge_max_block_size = 24216, old_parts_lifetime = 54., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 352967, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8593714033, index_granularity_bytes = 501653, concurrent_part_removal_threshold = 37, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 77506, primary_key_compress_block_size = 16568 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001116481c 10. /build/src/Interpreters/DDLWorker.cpp:662: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011162c3e 11. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 12. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 14. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:03.034125 [ 5777 ] {} DDLWorker(rdb2): Unexpected error (100 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:03.708444 [ 3049 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:03.757352 [ 3158 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:03.759296 [ 3158 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:04.710558 [ 3078 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:04.759322 [ 3270 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:04.763822 [ 3037 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:05.713556 [ 3090 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:05.761592 [ 3242 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:05.765783 [ 3186 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:06.725568 [ 3231 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:06.763841 [ 3081 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:06.767828 [ 3067 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:07.729868 [ 3236 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:07.765855 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:07.769932 [ 3247 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:08.035675 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:08.038644 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 0 to 42 2025.06.25 16:34:08.078039 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:08.078992 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:08.135558 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:08.731872 [ 3316 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:08.770149 [ 3168 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:08.772106 [ 3168 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:09.734225 [ 3011 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:09.772461 [ 3250 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:09.774654 [ 3309 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:10.736383 [ 3039 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:10.774755 [ 3472 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:10.776810 [ 3084 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:11.749431 [ 3098 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:11.781698 [ 3025 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:11.781826 [ 3216 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:12.751917 [ 3041 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:12.784520 [ 3046 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:12.788202 [ 3217 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:13.136780 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:13.139760 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:13.160371 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:13.161362 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:13.240900 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:13.754417 [ 3085 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:13.786934 [ 3227 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:13.790293 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:14.756641 [ 3142 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:14.795681 [ 3228 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:14.811144 [ 3212 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:15.761338 [ 3176 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:15.797962 [ 3119 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:15.815751 [ 3031 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:16.763541 [ 3333 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:16.800235 [ 3411 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:16.818173 [ 3277 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:17.767182 [ 3083 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:17.802268 [ 3167 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:17.820218 [ 3509 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:18.244442 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:18.247502 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:18.278661 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:18.279820 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:18.363515 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:18.769479 [ 3198 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:18.804481 [ 3462 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:18.822333 [ 3279 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:19.771584 [ 3255 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:19.808348 [ 3318 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:19.826447 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:20.780336 [ 3513 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:20.811123 [ 3191 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:20.828601 [ 3269 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:21.784700 [ 3406 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:21.816168 [ 3213 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:21.833644 [ 3329 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:22.786680 [ 3136 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:22.822967 [ 3511 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:22.838173 [ 3272 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:23.364751 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:23.371400 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:23.395724 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:23.397525 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:23.431339 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:23.789263 [ 3060 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:23.828257 [ 3038 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:23.840616 [ 3140 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:24.797549 [ 3152 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:24.830498 [ 3087 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:24.858355 [ 3249 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:25.799867 [ 3366 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:25.832809 [ 3280 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:25.860517 [ 3457 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:26.809720 [ 3093 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:26.845529 [ 3105 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:26.872624 [ 3465 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:27.676052 [ 3637 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fd2434af-e553-40a5-8c46-f5eaa8ed8ef5::202506_1_230_46}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:27.815488 [ 3482 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:27.847820 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:27.874874 [ 3141 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:28.435263 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:28.438871 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:28.571998 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:28.573177 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:28.677860 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:28.817475 [ 3216 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:28.850178 [ 3227 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:28.878658 [ 3336 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:29.819513 [ 3025 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:29.852387 [ 3517 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:29.880839 [ 3096 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:30.821905 [ 3342 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:30.854475 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:30.885818 [ 3426 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:31.830142 [ 3041 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:31.856889 [ 3154 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:31.891051 [ 3228 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:32.832508 [ 3346 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:32.859103 [ 3245 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:32.896180 [ 3153 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:33.679048 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:33.682489 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:33.710771 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:33.711949 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:33.834901 [ 3301 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:33.839808 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:33.861368 [ 3142 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:33.909224 [ 3161 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:34.837249 [ 3476 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:34.872866 [ 3466 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:34.914094 [ 3056 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:35.839422 [ 3176 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:35.875333 [ 3497 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:35.916615 [ 3119 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:36.841758 [ 3473 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:36.879850 [ 3031 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:36.919052 [ 3214 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:37.846321 [ 3506 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:37.882403 [ 3411 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:37.921493 [ 3362 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:38.841085 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:38.847142 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:38.851793 [ 3083 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:38.871718 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:38.872778 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:38.884386 [ 3470 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:38.923579 [ 3189 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:38.948415 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:39.854070 [ 3357 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:39.886537 [ 3184 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:39.925778 [ 3058 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:40.856096 [ 3459 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:40.888983 [ 3232 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:40.928294 [ 3198 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:41.865900 [ 3082 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:41.891127 [ 3334 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:41.930560 [ 3462 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:42.868110 [ 3045 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:42.893338 [ 3180 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:42.933064 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:43.880266 [ 3047 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:43.898543 [ 3027 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:43.935342 [ 3164 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:43.949660 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:43.953316 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:43.985342 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:43.986655 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:44.013750 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:44.888277 [ 3485 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:44.904032 [ 3175 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:44.937803 [ 3219 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:45.890365 [ 3059 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:45.906203 [ 3407 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:45.940152 [ 3481 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:46.892458 [ 3314 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:46.908410 [ 3329 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:46.942580 [ 3260 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:47.894974 [ 3483 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:47.911185 [ 3135 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:47.948077 [ 3276 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:48.897397 [ 3317 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:48.913434 [ 3499 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:48.950703 [ 3172 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:49.014902 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:49.017970 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:49.040349 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:49.041507 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:49.079631 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:49.899578 [ 3378 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:49.915698 [ 3299 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:49.953263 [ 3100 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:50.901740 [ 3335 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:50.918135 [ 3292 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:50.956879 [ 3006 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:51.906364 [ 3050 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:51.919971 [ 3333 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:51.979012 [ 3373 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:52.908690 [ 3497 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:52.924629 [ 3411 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:52.983714 [ 3484 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:53.910987 [ 3473 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:53.927011 [ 3277 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:53.986181 [ 3053 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:54.154928 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:54.158691 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:54.194463 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:54.195716 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:54.352597 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:54.913235 [ 3056 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:54.929275 [ 3043 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:54.988110 [ 3232 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:55.915119 [ 3120 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:55.934726 [ 3423 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:55.993576 [ 3095 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:56.917645 [ 3031 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:56.937020 [ 3189 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:56.995754 [ 3082 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:57.922032 [ 3267 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:57.939475 [ 3429 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:57.998189 [ 3493 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:58.924166 [ 3508 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:58.944139 [ 3076 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:59.000453 [ 3334 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:59.353694 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:59.357213 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:34:59.386077 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:34:59.387429 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:34:59.455328 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:59.926506 [ 3083 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:34:59.946318 [ 3389 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:00.002477 [ 3381 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:00.931039 [ 3184 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:00.948423 [ 3215 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:01.004433 [ 3462 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:01.933542 [ 3370 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:01.950562 [ 3167 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:02.095128 [ 3165 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:02.942442 [ 3319 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:02.956523 [ 3515 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:03.097496 [ 3291 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:03.945094 [ 3052 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:04.013457 [ 3045 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:04.100318 [ 3386 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:04.456492 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:04.463152 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:04.490416 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:04.491564 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:04.550338 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:04.951397 [ 3058 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:05.015290 [ 3180 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:05.102383 [ 3027 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:05.953623 [ 3459 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:06.020157 [ 3003 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:06.104535 [ 3516 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:06.955892 [ 3198 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:07.024453 [ 3221 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:07.108755 [ 3354 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:07.957983 [ 3196 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:08.029587 [ 3304 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:08.113583 [ 3294 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:08.959980 [ 3449 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:09.031674 [ 3164 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:09.117382 [ 3149 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:09.551500 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:09.554588 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:09.654821 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:09.655943 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:09.682016 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:09.962789 [ 3394 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:10.034849 [ 3016 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:10.119295 [ 3337 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:10.967785 [ 3230 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:11.036835 [ 3329 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:11.121903 [ 3135 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:11.972607 [ 3036 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:12.039019 [ 3062 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:12.124158 [ 3243 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:12.974728 [ 3480 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:13.043970 [ 3148 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:13.128556 [ 3330 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:13.979380 [ 3211 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:14.046359 [ 3310 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:14.130562 [ 3421 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:14.683229 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:14.689917 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:14.720307 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:14.721409 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:14.745264 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:14.981531 [ 3369 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:15.048840 [ 3299 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:15.132450 [ 3424 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:15.988599 [ 3315 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:16.051510 [ 3222 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:16.134793 [ 3292 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:16.986450 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:16.990741 [ 3425 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:17.056687 [ 3491 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:17.136980 [ 3091 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:17.992623 [ 3028 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:18.058779 [ 3216 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:18.139204 [ 3253 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:18.994835 [ 3082 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:19.063889 [ 3283 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:19.151720 [ 3513 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:19.746390 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:19.750175 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:19.862905 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:19.864124 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:19.898388 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:20.004888 [ 3493 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:20.065847 [ 3002 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:20.154311 [ 3219 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:21.006996 [ 3334 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:21.070578 [ 3117 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:21.201247 [ 3293 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:22.009585 [ 3381 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:22.072891 [ 3071 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:22.203680 [ 3321 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:23.013958 [ 3165 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:23.076231 [ 3009 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:23.205863 [ 3166 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.016999 [ 3045 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.078229 [ 3469 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.207950 [ 3490 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.712212 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0576d149-6ca8-4a86-ae51-efdadd389a86::202506_1_122_24}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.899822 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:24.908260 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:24.946029 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:24.947840 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:24.979237 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:25.019451 [ 3387 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:25.085597 [ 3229 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:25.213099 [ 3510 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:26.024597 [ 3221 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:26.090480 [ 3027 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:26.215274 [ 3057 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:27.027229 [ 3413 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:27.092648 [ 3516 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:27.217787 [ 3060 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:28.029511 [ 3449 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:28.094980 [ 3164 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:28.219483 [ 3038 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:29.031762 [ 3224 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:29.096843 [ 3456 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:29.227260 [ 3420 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:29.982785 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:29.987169 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:30.024019 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:30.025308 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:30.033723 [ 3382 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:30.062678 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:30.100615 [ 3339 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:30.229680 [ 3062 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:31.038189 [ 3255 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:31.103592 [ 3383 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:31.231427 [ 3439 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:32.042167 [ 3137 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:32.115322 [ 3394 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:32.235711 [ 3132 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:33.046434 [ 3318 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:33.118492 [ 3059 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:33.237674 [ 3379 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:34.048738 [ 3324 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:34.124372 [ 3230 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:34.239910 [ 3122 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:35.050942 [ 3314 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:35.064505 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:35.067612 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:35.094702 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:35.096057 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:35.126307 [ 3260 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:35.127927 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:35.242340 [ 3268 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:36.052971 [ 3272 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:36.128507 [ 3503 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:36.256208 [ 3152 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:37.058246 [ 3434 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:37.134354 [ 3249 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:37.261212 [ 3116 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:38.060509 [ 3326 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:38.136583 [ 3254 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:38.263500 [ 3023 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:39.062924 [ 3421 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:39.139074 [ 3287 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:39.271261 [ 3450 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.065292 [ 3461 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.129202 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.133724 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:40.143795 [ 3244 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.168635 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:40.169890 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:40.210623 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.273491 [ 3350 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:40.564362 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_310_365_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:41.069546 [ 3145 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:41.148713 [ 3093 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:41.275683 [ 3281 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:42.074480 [ 3427 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:42.164538 [ 3372 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:42.278937 [ 3055 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:43.173201 [ 3109 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:43.176361 [ 3375 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:43.283672 [ 3472 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:44.193463 [ 3232 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:44.206059 [ 3459 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:44.286428 [ 3095 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:45.208276 [ 3276 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:45.210163 [ 3166 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:45.211952 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:45.229359 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:45.258341 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:45.259582 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:45.288796 [ 3126 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:45.294167 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:46.210733 [ 3490 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:46.212497 [ 3510 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:46.293661 [ 3307 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:47.215159 [ 3340 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:47.216497 [ 3256 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:47.297187 [ 3254 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:48.217473 [ 3060 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:48.221812 [ 3140 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:48.299404 [ 3273 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:49.222862 [ 3420 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:49.227489 [ 3062 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:49.304403 [ 3051 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:50.228001 [ 3115 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:50.233872 [ 3439 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:50.295282 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:50.306446 [ 3494 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:50.306526 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:50.390825 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:50.392190 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:50.480204 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:51.230050 [ 3132 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:51.238646 [ 3243 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:51.311163 [ 3468 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:52.232568 [ 3379 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:52.243239 [ 3122 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:52.380534 [ 3421 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:53.236009 [ 3268 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:53.244617 [ 3479 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:53.382468 [ 3197 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:54.240755 [ 3395 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:54.247842 [ 3451 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:54.384255 [ 3266 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:55.243472 [ 3127 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:55.322395 [ 3148 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:55.387359 [ 3344 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:55.484267 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:55.487967 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:35:55.515437 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:35:55.516702 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:35:55.603163 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:56.248371 [ 3087 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:56.325251 [ 3185 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:56.389716 [ 3026 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:57.250799 [ 3330 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:57.327752 [ 3345 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:57.394832 [ 3103 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:58.254125 [ 3499 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:58.332946 [ 3133 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:58.396958 [ 3397 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:59.256111 [ 3172 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:59.335028 [ 3241 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:35:59.401820 [ 3504 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:00.258338 [ 3237 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:00.337695 [ 3461 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:00.404357 [ 3299 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:00.604523 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:00.608067 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:00.633253 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:00.634704 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:00.672837 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:01.260474 [ 3378 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:01.339697 [ 3392 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:01.369048 [ 3619 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_310_370_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:01.406446 [ 3007 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:02.262553 [ 3188 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:02.344614 [ 3292 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:02.410660 [ 3017 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:03.264413 [ 3477 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:03.346819 [ 3427 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:03.412506 [ 3405 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:04.269021 [ 3156 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:04.349377 [ 3507 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:04.414651 [ 3225 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:05.273746 [ 3433 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:05.354173 [ 3159 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:05.416524 [ 3465 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:05.674234 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:05.678088 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:05.714654 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:05.715749 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:05.780044 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:06.278883 [ 3415 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:06.356452 [ 3065 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:06.421198 [ 3308 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:07.280851 [ 3460 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:07.358526 [ 3313 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:07.454605 [ 3109 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:08.282967 [ 3040 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:08.360497 [ 3078 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:08.456771 [ 3247 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:09.285218 [ 3239 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:09.362626 [ 3204 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:09.459763 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:10.287292 [ 3136 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:10.458562 [ 3130 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:10.463761 [ 3272 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:10.781176 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:10.784901 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:10.812464 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:10.816104 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:10.848190 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:11.289682 [ 3126 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:11.461668 [ 3264 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:11.470828 [ 3074 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:12.291659 [ 3307 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:12.463785 [ 3069 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:12.473331 [ 3121 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:13.306224 [ 3051 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:13.465800 [ 3147 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:13.477488 [ 3188 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:14.310879 [ 3494 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:14.467769 [ 3171 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:14.479617 [ 3163 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:15.313197 [ 3468 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:15.469917 [ 3022 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:15.481950 [ 3145 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:15.849566 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:15.854192 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:15.882041 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:15.883445 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:15.960665 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:16.315804 [ 3287 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:16.474733 [ 3315 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:16.484202 [ 3335 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:17.317816 [ 3233 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:17.479643 [ 3520 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:17.486471 [ 3292 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:18.319671 [ 3201 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:18.482015 [ 3514 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:18.488348 [ 3008 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:19.325482 [ 3432 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:19.484109 [ 3077 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:19.490167 [ 3017 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:20.327573 [ 3139 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:20.492071 [ 3187 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:20.493375 [ 3110 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:20.962432 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:20.973155 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:21.074014 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:21.075371 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:21.110223 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:21.331132 [ 3112 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:21.495232 [ 3094 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:21.496187 [ 3093 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:22.286256 [ 3639 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {55fb2f07-fcda-417f-ada2-2bff1cfdc3cc::202506_310_375_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=35, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f597a7a2ac3 28. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:22.332822 [ 3345 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:22.497165 [ 3409 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:22.498019 [ 3202 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:23.334931 [ 3034 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:23.499867 [ 3405 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:23.501835 [ 3343 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:24.337024 [ 3133 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:24.507803 [ 3055 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:24.507982 [ 3372 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:25.342362 [ 3278 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:25.510705 [ 3488 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:25.512436 [ 3156 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:26.114202 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:26.118212 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:26.247720 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:26.249165 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:26.344418 [ 3303 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:26.358457 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:26.517123 [ 3225 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:26.512916 [ 3507 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:27.346814 [ 3014 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:27.522571 [ 3388 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:27.606872 [ 3365 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:28.383301 [ 3080 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:28.524746 [ 3111 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:28.608812 [ 3174 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:29.385441 [ 3290 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:29.526749 [ 3418 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:29.695478 [ 3090 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:30.387730 [ 3397 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:30.529184 [ 3151 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:30.698434 [ 3231 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:31.359682 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:31.363499 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:31.389693 [ 3378 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:31.390067 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:31.391316 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:31.464866 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:31.540115 [ 3285 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:31.700506 [ 3297 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:32.391760 [ 3226 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:32.544918 [ 3123 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:32.705501 [ 3160 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:33.393766 [ 3280 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:33.551182 [ 3150 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:33.710870 [ 3517 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:34.396193 [ 3442 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:34.553523 [ 3199 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:34.712887 [ 3497 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:35.400383 [ 3143 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:35.559907 [ 3506 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:35.720476 [ 3362 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:36.405378 [ 3319 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:36.486584 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:36.489925 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:36.521650 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:36.522818 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:36.555311 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:36.566373 [ 3053 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:36.722691 [ 3232 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:37.411040 [ 3130 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:37.568377 [ 3036 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:37.724520 [ 3062 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:38.413598 [ 3280 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:38.575413 [ 3437 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:38.732454 [ 3474 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:39.415930 [ 3457 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:39.651654 [ 3035 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:39.751194 [ 3160 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:40.418047 [ 3363 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:40.663586 [ 3296 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:40.756841 [ 3144 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:41.420218 [ 3248 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:41.556554 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:41.560744 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:41.593013 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:41.594076 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:41.621733 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:41.665746 [ 3040 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:41.759426 [ 3158 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:42.422668 [ 3042 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:42.668131 [ 3091 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:42.774411 [ 3270 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:43.424846 [ 3428 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:43.670347 [ 3452 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:43.776533 [ 3352 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:44.427078 [ 3118 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:44.672625 [ 3193 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:44.783055 [ 3262 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:45.428860 [ 3392 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:45.674828 [ 3223 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:45.785669 [ 3250 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:46.431180 [ 3355 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:46.623377 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:46.635007 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:46.681594 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:46.682811 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:46.707251 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:46.721916 [ 3289 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:46.788035 [ 3312 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:47.444254 [ 3495 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:47.728603 [ 3402 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:47.790874 [ 3309 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:48.446799 [ 3416 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:48.731189 [ 3113 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:48.793871 [ 3472 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:49.451669 [ 3074 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:49.733518 [ 3011 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:49.796780 [ 3403 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:50.460124 [ 3171 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:50.737614 [ 3259 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:50.799791 [ 3028 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:51.465404 [ 3121 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:51.711616 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:51.715307 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:51.740026 [ 3128 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:51.741565 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:51.742663 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:51.802183 [ 3235 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:51.827658 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:52.471798 [ 3007 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:52.745545 [ 3098 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:52.806678 [ 3025 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:53.474143 [ 3514 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:53.747841 [ 3041 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:53.811269 [ 3353 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:54.476391 [ 3008 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:54.752265 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:54.815810 [ 3012 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:55.492971 [ 3077 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:55.757689 [ 3376 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:55.819838 [ 3301 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.295485 [ 3624 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c944daf9-de77-4918-ae2f-90aeb61f7cdd::202506_1_226_115}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.495932 [ 3409 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.763557 [ 3517 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.822526 [ 3212 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.829352 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:56.832867 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:36:56.916703 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:36:56.918562 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:36:56.952748 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:57.096213 [ 45257 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000010886fab 4. /build/src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108864b7 5. /build/src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000108858b6 6. /build/contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000010885b63 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9794 8. /build/src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000110e9c8b 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x0000000012c4c285 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 11. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 12. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 15. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 16. ? @ 0x00007f597a7a2ac3 17. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:57.498547 [ 3427 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:57.766072 [ 3214 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:57.824611 [ 3411 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:58.501090 [ 3343 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:58.770884 [ 3502 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:58.826836 [ 3104 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:59.504265 [ 3055 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:59.775705 [ 3484 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:36:59.829200 [ 3319 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:00.506432 [ 3183 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:00.778280 [ 3180 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:00.833905 [ 3003 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:01.508697 [ 3388 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:01.780807 [ 3394 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:01.836089 [ 3337 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:01.954006 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:01.958101 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:01.981112 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:01.982059 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:02.109125 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:02.513290 [ 3404 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:02.782871 [ 3181 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:02.845242 [ 3435 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:03.515185 [ 3061 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:03.784940 [ 3010 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:03.847652 [ 3152 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:04.520445 [ 3156 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:04.818419 [ 3195 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:04.850385 [ 3012 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:05.523593 [ 3111 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:05.821201 [ 3342 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:05.855322 [ 3519 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:06.525714 [ 3015 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:06.823431 [ 3041 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:06.860582 [ 3376 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:07.110355 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:07.113999 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:07.216147 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:07.217113 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:07.237992 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:07.530298 [ 3033 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:07.827985 [ 3046 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:07.863111 [ 3154 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:08.533045 [ 3444 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:08.834446 [ 3353 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:08.868829 [ 3212 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:09.536782 [ 3005 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:09.836573 [ 3360 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:09.897603 [ 3228 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:10.542515 [ 3024 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:10.838950 [ 3306 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:10.899965 [ 3153 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:11.544508 [ 3320 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:11.792780 [ 3639 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c944daf9-de77-4918-ae2f-90aeb61f7cdd::202506_1_228_117}: 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000c66c26b 4. /build/src/Common/MemoryTracker.cpp:0: MemoryTracker::injectFault() const @ 0x000000000c66a83d 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000012aace19 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac411 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 9. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 10. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f597a7a2ac3 14. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:11.841499 [ 3517 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:11.902424 [ 3161 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:12.239283 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:12.242954 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:12.274770 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:12.275981 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:12.374839 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:12.546714 [ 3389 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:12.843689 [ 3253 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:12.908879 [ 3134 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:13.548860 [ 3404 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:13.846008 [ 3301 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:13.914504 [ 3473 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:14.552097 [ 3433 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:14.848448 [ 3142 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:14.921705 [ 3120 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:15.556845 [ 3159 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:15.853927 [ 3466 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:15.924313 [ 3267 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:16.558680 [ 3282 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:16.856077 [ 3141 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:16.926696 [ 3508 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:17.375870 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:17.381898 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:17.416022 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:17.417207 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:17.444864 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:17.560634 [ 3368 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:17.860511 [ 3336 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:17.947768 [ 3423 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:18.565444 [ 3075 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:18.862770 [ 3143 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:18.955539 [ 3184 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:19.567474 [ 3460 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:19.867434 [ 3031 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:19.960650 [ 3370 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:20.569622 [ 3399 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:20.869645 [ 3362 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:20.964915 [ 3167 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:21.571891 [ 3123 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:21.874268 [ 3319 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:21.967963 [ 3058 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:22.448363 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:22.451673 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:22.485186 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:22.486531 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:22.514402 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:22.574724 [ 3425 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:22.878595 [ 3053 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:23.022048 [ 3413 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:23.577201 [ 3518 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:23.881208 [ 3082 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:24.026501 [ 3486 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:24.579151 [ 3061 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:24.886185 [ 3374 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:25.028418 [ 3269 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:25.581459 [ 3246 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:25.888452 [ 3149 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:26.032586 [ 3219 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:26.586206 [ 3240 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:26.892819 [ 3324 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:27.068455 [ 3203 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:27.515873 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:27.519407 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:27.545997 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:27.547030 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:27.598544 [ 3521 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:27.599501 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:27.982518 [ 3030 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:28.070762 [ 3135 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:28.600398 [ 3284 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:28.984740 [ 3152 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:29.073051 [ 3148 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:29.602600 [ 3438 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:29.987820 [ 3073 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:30.076604 [ 3343 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:30.605351 [ 3399 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:30.993040 [ 3198 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:31.078520 [ 3471 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:31.607805 [ 3365 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:31.995472 [ 3082 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:32.080876 [ 3302 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:32.600580 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:32.612289 [ 3285 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:32.614252 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:32.641920 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:32.642964 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:32.749671 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:32.999110 [ 3334 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:33.082858 [ 3305 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:33.614747 [ 3019 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:34.006499 [ 3381 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:34.087231 [ 3469 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:34.620088 [ 3123 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:35.017352 [ 3003 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:35.089189 [ 3229 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:35.622886 [ 3436 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:36.022358 [ 3221 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:36.103938 [ 3027 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:36.625733 [ 3271 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:37.026311 [ 3196 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:37.109559 [ 3354 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:37.629986 [ 3518 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:37.750795 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:37.762696 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:37.788695 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:37.790010 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:37.818022 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:38.030059 [ 3013 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:38.111978 [ 3018 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:38.632971 [ 3375 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:39.032268 [ 3486 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:39.114246 [ 3108 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:39.634819 [ 3371 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:40.040478 [ 3356 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:40.144312 [ 3200 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:40.639738 [ 3445 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:41.042828 [ 3224 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:41.146243 [ 3269 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:41.645813 [ 3246 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:42.047391 [ 3382 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:42.148081 [ 3175 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:42.648270 [ 3265 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:42.819513 [ 5777 ] {} DDLWorker(rdb2): Database got stuck at processing task query-0000000003: it failed 100 times in a row with the same error. Will reset digest to mark our replica as lost, and trigger recovery from the most up-to-date metadata from ZooKeeper. See max_retries_before_automatic_recovery setting. The error: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007038d2b 4. /build/src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000011163345 5. /build/src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000111604d3 6. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DDLWorker::runMainThread() @ 0x000000001115a3ee 7. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:42.823778 [ 5777 ] {} DDLWorker(rdb2): Resetting digest from 42 to 42 2025.06.25 16:37:42.856916 [ 5777 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:37:42.858404 [ 5777 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:37:42.883972 [ 5777 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f597a7a2ac3 16. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:43.050149 [ 3255 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:43.149994 [ 3149 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:43.650563 [ 3092 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:44.052803 [ 3512 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:44.152265 [ 3394 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:44.657601 [ 3508 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:45.055863 [ 3490 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:45.157821 [ 3435 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:45.662019 [ 3379 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:46.057127 [ 3210 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:46.159065 [ 3407 ] {} test_h1oxk40k.table_for_rename_pk (e4d38916-13b7-47a9-88fa-52023768d07f): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1oxk40k/test_01213/table_for_rename_pk1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:46.662579 [ 3284 ] {} rdb1.t (3c88d60e-a2de-4d80-b1b3-24faf63d56d3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:37:47.057506 [ 3302 ] {} test_q8l09y0g.t_limit_mutations (cfd6e730-c3db-4ee3-961e-fc6d2c0b77e5): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_q8l09y0g/t_limit_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000702000b 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000012344864 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000123b6c01 6. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 7. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 8. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 9. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 11. ? @ 0x00007f597a7a2ac3 12. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:38:47.203999 [ 53412 ] {852b7ab9-24cf-4cdd-9311-33dd22524c19} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.014944987 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54396) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:38:47.204290 [ 53412 ] {852b7ab9-24cf-4cdd-9311-33dd22524c19} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.014944987 seconds, maximum: 60. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000010bfd68b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:0: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000010bfcd9a 5. /build/contrib/llvm-project/libcxx/include/atomic:958: DB::PipelineExecutor::finalizeExecution() @ 0x0000000012d607f0 6. /build/src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa84 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 8. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 10. ? @ 0x00007f597a7a2ac3 11. ? @ 0x00007f597a834850 2025.06.25 16:38:47.518350 [ 59467 ] {2a9ff5ec-b4d5-4b0f-acce-12b0688f39b2} executeQuery: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51726) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000010dc746e 4. /build/src/Common/atomicRename.cpp:0: DB::renameat2(String const&, String const&, int) @ 0x0000000010dc7282 5. /build/src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000010dc6e5a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154afcf 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 2025.06.25 16:38:47.518753 [ 59467 ] {2a9ff5ec-b4d5-4b0f-acce-12b0688f39b2} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000010dc746e 4. /build/src/Common/atomicRename.cpp:0: DB::renameat2(String const&, String const&, int) @ 0x0000000010dc7282 5. /build/src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000010dc6e5a 6. /build/contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000001154afcf 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x000000001156260b 8. /build/src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000011911056 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000011913b14 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012c4ca43 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000012c4f451 12. /build/base/poco/Foundation/include/Poco/AutoPtr.h:205: DB::HTTPServerConnection::run() @ 0x0000000012cd6521 13. /build/base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000016528c87 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001652915e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000164d5972 16. /build/base/poco/Foundation/include/Poco/AutoPtr.h:77: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000164d3683 17. ? @ 0x00007f597a7a2ac3 18. ? @ 0x00007f597a834850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:38:50.867246 [ 2947 ] {} Application: Closed all listening sockets. Waiting for 16 outstanding connections. 2025.06.25 16:38:55.773327 [ 2947 ] {} Application: Closed connections. But 16 remain. Tip: To increase wait time add to config: 60 2025.06.25 16:38:55.773410 [ 2947 ] {} Application: Will shutdown forcefully. 2025.06.25 16:38:57.030291 [ 59608 ] {} Context: Server was built in debug mode. It will work slowly. 2025.06.25 16:38:57.037498 [ 59608 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.06.25 16:38:57.037899 [ 59608 ] {} 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.06.25 16:38:57.038140 [ 59608 ] {} 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.06.25 16:38:57.492178 [ 59608 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.06.25 16:38:57.493652 [ 59608 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.06.25 16:38:57.493676 [ 59608 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.06.25 16:38:57.544441 [ 60217 ] {} RaftInstance: Election timeout, initiate leader election 2025.06.25 16:38:58.291737 [ 59608 ] {} 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.06.25 16:38:58.323882 [ 59608 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.06.25 16:38:58.324907 [ 59608 ] {} Context: Server has databases (for example `test1601_detach_permanently_ordinary`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.06.25 16:38:58.519324 [ 59608 ] {} TablesLoader: Tables test_6kav04bt.test_dictionary_non_nullable depend on test_6kav04bt.dictionary_non_nullable_source_table, but seems like that does not exist. Will ignore it and try to load existing tables 2025.06.25 16:38:58.519442 [ 59608 ] {} TablesLoader: Tables test_jumtem4b.flat_dictionary depend on test_jumtem4b.dictionary_decimal_source_table, but seems like that does not exist. Will ignore it and try to load existing tables 2025.06.25 16:38:58.519489 [ 59608 ] {} TablesLoader: Tables test_13.distributed, test_11.distributed depend on default.x, but seems like that does not exist. Will ignore it and try to load existing tables 2025.06.25 16:38:58.600219 [ 59649 ] {} void DB::BackgroundJobsAssignee::threadFunc(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=749, jobs=715). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70a9f3 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c70590c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c70614d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001186eaaf 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:833: DB::TransactionLog::TransactionLog() @ 0x0000000011865dff 9. /build/contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::SingletonHelper::createInstanceOrThrow() @ 0x0000000007b62787 10. /build/src/Interpreters/TransactionLog.h:0: DB::StorageMergeTree::scheduleDataProcessingJob(DB::BackgroundJobsAssignee&) @ 0x0000000012a85bda 11. /build/src/Storages/MergeTree/BackgroundJobsAssignee.cpp:0: DB::BackgroundJobsAssignee::threadFunc() @ 0x00000000126a2925 12. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 13. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 14. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 15. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 17. ? @ 0x00007f77ff5b0ac3 18. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:38:58.602277 [ 59628 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012515a51 9. /build/src/Storages/StorageBuffer.cpp:1088: DB::StorageBuffer::backgroundFlush() @ 0x0000000012518fb2 10. /build/src/Common/Stopwatch.h:86: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000010967c94 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001096a8f4 12. /build/src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001096aec7 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:38:58.607198 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:38:58.607254 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:38:58.608113 [ 60348 ] {} DDLWorker(test_7xi1res5): Replica seems to be lost: our_log_ptr=16, max_log_ptr=16, local_digest=7470437202976543065, zk_digest=13415760526437320034 2025.06.25 16:38:58.608352 [ 60348 ] {} DatabaseReplicated (test_7xi1res5): Will recover replica with staled log pointer 16 from log pointer 16 2025.06.25 16:38:58.620310 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:38:58.646906 [ 59614 ] {d24e61ee-c7fb-4f42-bc2f-4ca2d0b21e48} 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.10505.altinitytest (altinity build)) (from [::1]:56204) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:38:58.647150 [ 59614 ] {d24e61ee-c7fb-4f42-bc2f-4ca2d0b21e48} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:03.622240 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:39:03.622281 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:39:03.626643 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:03.728231 [ 59614 ] {8b9dc793-a0e3-4afe-9001-bb14cec5c1a8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56214) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:03.728478 [ 59614 ] {8b9dc793-a0e3-4afe-9001-bb14cec5c1a8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:08.629010 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:39:08.629051 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:39:08.633386 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:08.810981 [ 59614 ] {f0663ae4-8017-4fe8-8178-b90f9874c84a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38856) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:08.811139 [ 59614 ] {f0663ae4-8017-4fe8-8178-b90f9874c84a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:12.380977 [ 60226 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fd2434af-e553-40a5-8c46-f5eaa8ed8ef5::202506_1_270_54}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f77ff5b0ac3 28. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:13.635282 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:39:13.635404 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:39:13.639490 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:13.892911 [ 59614 ] {e1fa1cbe-92bd-461f-ad4a-fa373d01f31d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38858) (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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:13.893460 [ 59614 ] {e1fa1cbe-92bd-461f-ad4a-fa373d01f31d} 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012d61899 8. /build/src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x0000000012d5fff4 9. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x0000000012d5fa45 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000012d6e10a 11. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 13. ? @ 0x00007f77ff5b0ac3 14. ? @ 0x00007f77ff642850 2025.06.25 16:39:18.641426 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:39:18.641462 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:39:18.645499 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:29.068897 [ 60358 ] {} DDLWorker(rdb2): Replica seems to be lost: our_log_ptr=1, max_log_ptr=3, local_digest=0, zk_digest=42 2025.06.25 16:39:29.068947 [ 60358 ] {} DatabaseReplicated (rdb2): Will recover replica with staled log pointer 1 from log pointer 3 2025.06.25 16:39:29.072837 [ 60358 ] {} DDLWorker(rdb2): Error on initialization of rdb2: Code: 57. DB::Exception: Directory for table data store/3c8/3c88d60e-a2de-4d80-b1b3-24faf63d56d3/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000701056b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x000000001155f4d9 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000115586fa 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x0000000011562612 7. /build/src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000010df3b35 8. /build/contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000010dedd68 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000010e057f4 10. /build/contrib/llvm-project/libcxx/include/atomic:945: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000010e03b08 11. /build/src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000001115a191 12. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000111713c2 13. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 15. ? @ 0x00007f77ff5b0ac3 16. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:30.823781 [ 60226 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e2f926bf-3a9c-45ec-94f7-f1a9f1216744::202506_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c707f4c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bf749 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000128bd147 9. /build/contrib/llvm-project/libcxx/include/future:1062: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x00000000128bcf7f 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x00000000128d880c 11. /build/contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000001282618a 12. /build/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 @ 0x0000000012823a1d 13. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: 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) @ 0x00000000128fb3d7 14. /build/contrib/llvm-project/libcxx/include/optional:260: 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&) @ 0x00000000128fe01f 15. /build/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) @ 0x00000000128fcf83 16. /build/src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x00000000127547f3 17. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x0000000012751a3c 18. /build/src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x0000000012757119 19. /build/src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001275b90a 20. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000012aac424 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000012773444 22. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x0000000012773dfe 23. /build/src/Common/ThreadPool.cpp:781: ThreadPoolImpl>::ThreadFromThreadPool::worker() @ 0x000000000c706f7f 24. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000c70c102 25. /build/base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000c704d0e 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000c70a172 27. ? @ 0x00007f77ff5b0ac3 28. ? @ 0x00007f77ff642850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.06.25 16:39:34.106928 [ 59608 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): 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. /build/contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000164836b2 1. /build/src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000c650159 2. /build/contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000700f16c 3. /build/contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000c70ac2b 4. /build/src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000c70c453 5. /build/contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000c7085f2 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000c707dae 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000010404241 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000012515a51 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001251578d 10. /build/contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000012515564 11. /build/contrib/llvm-project/libcxx/include/__tree:188: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000010e11775 12. /build/contrib/llvm-project/libcxx/include/__tree:188: DB::DatabaseCatalog::shutdownImpl() @ 0x0000000011174f63 13. /build/src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x000000001110795b 14. /build/programs/server/Server.cpp:936: BasicScopeGuard> const&)::$_2>::~BasicScopeGuard() @ 0x000000000c7e0949 15. /build/programs/server/Server.cpp:0: DB::Server::main(std::vector> const&) @ 0x000000000c7d4099 16. /build/base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x000000001654a086 17. /build/programs/server/Server.cpp:397: DB::Server::run() @ 0x000000000c7c0ee2 18. /build/programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x000000000c7bea93 19. /build/contrib/llvm-project/libcxx/include/vector:438: main @ 0x0000000007008c6b 20. ? @ 0x00007f77ff545d90 21. ? @ 0x00007f77ff545e40 22. _start @ 0x000000000700802e (version 24.8.14.10505.altinitytest (altinity build))